conflict_resolution
stringlengths 27
16k
|
---|
<<<<<<<
String cseEventStream = "@Plan:playback(idleTime = '100 millisecond', increment = '4 sec') define stream " +
"cseEventStream (symbol string, price float, volume int);";
=======
String cseEventStream = "@Plan:playback(idle.time = '100 millisecond', increment = '4 sec') define stream cseEventStream (symbol string, price float, volume int);";
>>>>>>>
String cseEventStream = "@Plan:playback(idle.time = '100 millisecond', increment = '4 sec') define stream " +
"cseEventStream (symbol string, price float, volume int);"; |
<<<<<<<
<li class=new-in-release>Support distributionChannels field to Store and add update action {@link io.sphere.sdk.stores.commands.updateactions.SetDistributionChannels}, {@link io.sphere.sdk.stores.commands.updateactions.AddDistributionChannel} and {@link io.sphere.sdk.stores.commands.updateactions.RemoveDistributionChannel}</li>
=======
<li class=new-in-release>Support LanguageUsedInStore error {@link io.sphere.sdk.projects.error.LanguageUsedInStores}</li>
>>>>>>>
<li class=new-in-release>Support distributionChannels field to Store and add update action {@link io.sphere.sdk.stores.commands.updateactions.SetDistributionChannels}, {@link io.sphere.sdk.stores.commands.updateactions.AddDistributionChannel} and {@link io.sphere.sdk.stores.commands.updateactions.RemoveDistributionChannel}</li>
<li class=new-in-release>Support LanguageUsedInStore error {@link io.sphere.sdk.projects.error.LanguageUsedInStores}</li> |
<<<<<<<
/**
* Parse single InputStream and return SingleStreamRuntime
*
* @param inputStream single input stream to be parsed
* @param context query to be parsed
* @param metaStreamEvent Meta event used to collect execution info of stream associated with query
* @param executors List to hold VariableExpressionExecutors to update after query parsing
* @return
*/
public static SingleStreamRuntime parseInputStream(SingleInputStream inputStream, SiddhiContext context, MetaStreamEvent metaStreamEvent, List<VariableExpressionExecutor> executors) {
=======
public static SingleStreamRuntime parseInputStream(SingleInputStream inputStream, SiddhiContext context,
MetaStreamEvent metaStreamEvent, List<VariableExpressionExecutor> executors) {
>>>>>>>
/**
* Parse single InputStream and return SingleStreamRuntime
*
* @param inputStream single input stream to be parsed
* @param context query to be parsed
* @param metaStreamEvent Meta event used to collect execution info of stream associated with query
* @param executors List to hold VariableExpressionExecutors to update after query parsing
* @return
*/
public static SingleStreamRuntime parseInputStream(SingleInputStream inputStream, SiddhiContext context, MetaStreamEvent metaStreamEvent, List<VariableExpressionExecutor> executors) {
public static SingleStreamRuntime parseInputStream(SingleInputStream inputStream, SiddhiContext context,
MetaStreamEvent metaStreamEvent, List<VariableExpressionExecutor> executors) {
<<<<<<<
return new FilterProcessor(ExpressionParser.parseExpression(condition, context, metaStreamEvent, executors)); //metaStreamEvent has stream definition info
=======
try {
return new FilterProcessor(ExpressionParser.parseExpression(condition, null, context, null, metaStreamEvent, executors,false)); //metaStreamEvent has stream definition info
} catch (ValidatorException e) {
//This will never occur
return null;
}
>>>>>>>
return new FilterProcessor(ExpressionParser.parseExpression(condition, context, metaStreamEvent, executors,false)); //metaStreamEvent has stream definition info |
<<<<<<<
<h3 class=released-version id="v1_53_0">1.53.0 (10.08.2020)</h3>
<ul>
<li class=new-in-release>Added new {@link io.sphere.sdk.shippingmethods.queries.ShippingMethodsByOrderEditGet}.</li>
</ul>
=======
<h3 class=released-version id="v1_53_0">1.53.0 (10.08.2020)</h3>
<ul>
<li class=new-in-release>Added new {@link io.sphere.sdk.inventory.messages.InventoryEntryCreatedMessage}.</li>
</ul>
>>>>>>>
<h3 class=released-version id="v1_53_0">1.53.0 (10.08.2020)</h3>
<ul>
<li class=new-in-release>Added new {@link io.sphere.sdk.shippingmethods.queries.ShippingMethodsByOrderEditGet}.</li>
<li class=new-in-release>Added new {@link io.sphere.sdk.inventory.messages.InventoryEntryCreatedMessage}.</li>
</ul> |
<<<<<<<
* @param streamDefinition The stream definition
=======
*
* @param streamDefinition The stream definition
>>>>>>>
* * @param streamDefinition The stream definition
<<<<<<<
SinkListener sinkListener)
throws ConnectionUnavailableException {
=======
SinkListener sinkListener, DynamicOptions dynamicOptions) {
>>>>>>>
SinkListener sinkListener) {
<<<<<<<
sinkListener.publish(sb.toString());
=======
sinkListener.publishEvents(sb.toString(), dynamicOptions);
>>>>>>>
sinkListener.publishEvents(sb.toString());
<<<<<<<
* @param events Event object array
* @param optionHolder option holder containing static and dynamic options
* @param payloadTemplateBuilder Unmapped payload for reference
* @param sinkListener output transport callback
=======
*
* @param events Event object array
* @param optionHolder option holder containing static and dynamic options
* @param payloadTemplateBuilder Unmapped payload for reference
* @param sinkListener output transport callback
>>>>>>>
* @param events Event object array
* @param optionHolder option holder containing static and dynamic options
* @param payloadTemplateBuilder Unmapped payload for reference
* @param sinkListener output transport callback
<<<<<<<
SinkListener sinkListener)
throws ConnectionUnavailableException {
=======
SinkListener sinkListener, DynamicOptions dynamicOptions) {
>>>>>>>
SinkListener sinkListener) {
<<<<<<<
sinkListener.publish(sb.toString());
=======
sinkListener.publishEvents(sb.toString(), dynamicOptions);
>>>>>>>
sinkListener.publishEvents(sb.toString()); |
<<<<<<<
Map<TimePeriod.Duration, IncrementalExecutor> incrementalExecutorMap,
Map<TimePeriod.Duration, Table> aggregationTables,
SingleStreamRuntime singleStreamRuntime,
EntryValveExecutor entryValveExecutor, List<TimePeriod.Duration> incrementalDurations,
SiddhiAppContext siddhiAppContext, List<ExpressionExecutor> baseExecutors,
ExpressionExecutor timestampExecutor, MetaStreamEvent tableMetaStreamEvent,
List<ExpressionExecutor> outputExpressionExecutors,
LatencyTracker latencyTrackerFind, ThroughputTracker throughputTrackerFind) {
=======
Map<TimePeriod.Duration, IncrementalExecutor> incrementalExecutorMap,
Map<TimePeriod.Duration, Table> aggregationTables, SingleStreamRuntime singleStreamRuntime,
EntryValveExecutor entryValveExecutor, List<TimePeriod.Duration> incrementalDurations,
SiddhiAppContext siddhiAppContext, List<ExpressionExecutor> baseExecutors,
ExpressionExecutor timestampExecutor, MetaStreamEvent tableMetaStreamEvent,
List<ExpressionExecutor> outputExpressionExecutors) {
>>>>>>>
Map<TimePeriod.Duration, IncrementalExecutor> incrementalExecutorMap,
Map<TimePeriod.Duration, Table> aggregationTables, SingleStreamRuntime singleStreamRuntime,
EntryValveExecutor entryValveExecutor, List<TimePeriod.Duration> incrementalDurations,
SiddhiAppContext siddhiAppContext, List<ExpressionExecutor> baseExecutors,
ExpressionExecutor timestampExecutor, MetaStreamEvent tableMetaStreamEvent,
List<ExpressionExecutor> outputExpressionExecutors,
LatencyTracker latencyTrackerFind, ThroughputTracker throughputTrackerFind) {
<<<<<<<
=======
Table tableForPerDuration = aggregationTables.get(perValue);
Long[] startTimeEndTime = (Long[]) startTimeEndTimeExpressionExecutor.execute(matchingEvent);
return ((IncrementalAggregateCompileCondition) compiledCondition).find(matchingEvent, perValue,
incrementalExecutorMap, incrementalDurations, tableForPerDuration, baseExecutors, timestampExecutor,
outputExpressionExecutors, startTimeEndTime);
>>>>>>> |
<<<<<<<
throw new ExecutionPlanValidationException("Playback annotation accepts only idleTime and " +
"increment but found " + e.getKey());
=======
throw new ExecutionPlanValidationException("Playback annotation accepts only idle.time and increment but found " + e.getKey());
>>>>>>>
throw new ExecutionPlanValidationException("Playback annotation accepts only idle.time and " +
"increment but found " + e.getKey());
<<<<<<<
throw new ExecutionPlanValidationException("Playback annotation requires both idleTime and " +
"increment but increment not found");
=======
throw new ExecutionPlanValidationException("Playback annotation requires both idle.time and increment but increment not found");
>>>>>>>
throw new ExecutionPlanValidationException("Playback annotation requires both idle.time and " +
"increment but increment not found");
<<<<<<<
throw new ExecutionPlanValidationException("Playback annotation requires both idleTime and " +
"increment but idleTime does not found");
=======
throw new ExecutionPlanValidationException("Playback annotation requires both idle.time and increment but idle.time does not found");
>>>>>>>
throw new ExecutionPlanValidationException("Playback annotation requires both idle.time and " +
"increment but idle.time does not found");
<<<<<<<
throw new SiddhiParserException("Invalid idleTime constant '" + idleTime + "' in playback " +
"annotation", ex);
=======
throw new SiddhiParserException("Invalid idle.time constant '" + idleTime + "' in playback annotation", ex);
>>>>>>>
throw new SiddhiParserException("Invalid idle.time constant '" + idleTime + "' in playback " +
"annotation", ex);
<<<<<<<
eventWindow.init(executionPlanRuntimeBuilder.getEventTableMap(), executionPlanRuntimeBuilder
.getEventWindowMap(), latencyTracker, eventWindow.getWindowDefinition().getId());
=======
window.init(executionPlanRuntimeBuilder.getTableMap(), executionPlanRuntimeBuilder.getEventWindowMap(), latencyTracker, window.getWindowDefinition().getId());
>>>>>>>
window.init(executionPlanRuntimeBuilder.getTableMap(), executionPlanRuntimeBuilder
.getEventWindowMap(), latencyTracker, window.getWindowDefinition().getId()); |
<<<<<<<
/**
* @since Dec 23, 2015
*/
public class ExternalTimeBatchWindowProcessor extends WindowProcessor implements FindableProcessor {
=======
public class ExternalTimeBatchWindowProcessor extends WindowProcessor implements SchedulingProcessor, FindableProcessor {
>>>>>>>
public class ExternalTimeBatchWindowProcessor extends WindowProcessor implements SchedulingProcessor, FindableProcessor {
<<<<<<<
static final Logger log = Logger.getLogger(ExternalTimeBatchWindowProcessor.class);
private ExpressionExecutor timestampExpressionExecutor;
=======
private VariableExpressionExecutor timeStampVariableExpressionExecutor;
>>>>>>>
private VariableExpressionExecutor timeStampVariableExpressionExecutor;
<<<<<<<
timestampExpressionExecutor = attributeExpressionExecutors[0];
=======
} else if (attributeExpressionExecutors.length == 3 || attributeExpressionExecutors.length == 4) {
isStartTimeEnabled = true;
>>>>>>>
timestampExpressionExecutor = attributeExpressionExecutors[0];
<<<<<<<
throw new ExecutionPlanValidationException("ExternalTimeBatch window should only have two or three parameters (<long> timestamp, <int|long|time> windowTime) or (<long> timestamp, <int|long|time> windowTime, <long> startTime), but found " + attributeExpressionExecutors.length + " input attributes");
=======
throw new ExecutionPlanValidationException("ExternalTime window should only have two/three parameter (<long> timeStamp, <int|long|time> windowTime (and <int> startTime) ), but found " + attributeExpressionExecutors.length + " input attributes");
>>>>>>>
throw new ExecutionPlanValidationException("ExternalTimeBatch window should only have two to four parameters (<long> timestamp, <int|long|time> windowTime, <long> startTime, <int|long|time> timeout), but found " + attributeExpressionExecutors.length + " input attributes");
<<<<<<<
StreamEvent streamEvent = streamEventChunk.getFirst();
while (streamEvent != null) {
StreamEvent currStreamEvent = streamEvent;
streamEvent = streamEvent.getNext();
if (currStreamEvent.getType() != ComplexEvent.Type.CURRENT) {
continue;
}
long currentTime = (Long) timestampExpressionExecutor.execute(currStreamEvent);
if (currentTime < endTime) {
cloneAppend(streamEventCloner, currStreamEvent);
} else if (currentTime >= endTime) {
ComplexEventChunk<StreamEvent> newEventChunk = new ComplexEventChunk<StreamEvent>();
// mark the timestamp for the expiredType event
expiredEventChunk.reset();
while (expiredEventChunk.hasNext()) {
StreamEvent expiredEvent = expiredEventChunk.next();
expiredEvent.setTimestamp(currentTime);
}
// add expired event to newEventChunk.
if (expiredEventChunk.getFirst() != null) {
newEventChunk.add(expiredEventChunk.getFirst());
}
expiredEventChunk.clear();
// need flush the currentEventChunk
currentEventChunk.reset();
while (currentEventChunk.hasNext()) {
StreamEvent currentEvent = currentEventChunk.next();
StreamEvent toExpireEvent = streamEventCloner.copyStreamEvent(currentEvent);
toExpireEvent.setType(StreamEvent.Type.EXPIRED);
expiredEventChunk.add(toExpireEvent);
}
// add current event chunk to next processor
if (currentEventChunk.getFirst() != null) {
newEventChunk.add(currentEventChunk.getFirst());
}
currentEventChunk.clear();
// update timestamp, call next processor
endTime += timeToKeep;
if (newEventChunk.getFirst() != null) {
complexEventChunks.add(newEventChunk);
}
cloneAppend(streamEventCloner, currStreamEvent);
}
=======
long currentTime = (Long) currStreamEvent.getAttribute(timeStampVariableExpressionExecutor.getPosition());
if (currentTime < endTime) {
cloneAppend(streamEventCloner, currStreamEvent);
} else if (currentTime >= endTime) {
flushCurrentChunk(nextProcessor, streamEventCloner, currentTime);
cloneAppend(streamEventCloner, currStreamEvent);
>>>>>>>
StreamEvent streamEvent = streamEventChunk.getFirst();
while (streamEvent != null) {
StreamEvent currStreamEvent = streamEvent;
streamEvent = streamEvent.getNext();
if (currStreamEvent.getType() == ComplexEvent.Type.TIMER) {
if (lastScheduledTime <= currStreamEvent.getTimestamp()) {
// implies that there have not been any more events after this schedule has been done.
flushCurrentChunk(nextProcessor, streamEventCloner, lastCurrentEventTime);
// rescheduling to emit the current batch after expiring it if no further events arrive.
lastScheduledTime = executionPlanContext.getTimestampGenerator().currentTime() + schedulerTimeout;
lastCurrentEventTime = lastCurrentEventTime + timeToKeep;
scheduler.notifyAt(lastScheduledTime);
}
continue;
} else if (currStreamEvent.getType() != ComplexEvent.Type.CURRENT) {
continue;
}
long currentTime = (Long) timestampExpressionExecutor.execute(currStreamEvent);
if (currentTime < endTime) {
cloneAppend(streamEventCloner, currStreamEvent);
} else if (currentTime >= endTime) {
ComplexEventChunk<StreamEvent> newEventChunk = new ComplexEventChunk<StreamEvent>();
// mark the timestamp for the expiredType event
expiredEventChunk.reset();
while (expiredEventChunk.hasNext()) {
StreamEvent expiredEvent = expiredEventChunk.next();
expiredEvent.setTimestamp(currentTime);
}
// add expired event to newEventChunk.
if (expiredEventChunk.getFirst() != null) {
newEventChunk.add(expiredEventChunk.getFirst());
}
expiredEventChunk.clear();
// need flush the currentEventChunk
currentEventChunk.reset();
while (currentEventChunk.hasNext()) {
StreamEvent currentEvent = currentEventChunk.next();
StreamEvent toExpireEvent = streamEventCloner.copyStreamEvent(currentEvent);
toExpireEvent.setType(StreamEvent.Type.EXPIRED);
expiredEventChunk.add(toExpireEvent);
}
// add current event chunk to next processor
if (currentEventChunk.getFirst() != null) {
newEventChunk.add(currentEventChunk.getFirst());
}
currentEventChunk.clear();
// update timestamp, call next processor
endTime += timeToKeep;
if (newEventChunk.getFirst() != null) {
complexEventChunks.add(newEventChunk);
}
cloneAppend(streamEventCloner, currStreamEvent);
// triggering the last batch expiration.
if (schedulerTimeout > 0) {
lastScheduledTime = executionPlanContext.getTimestampGenerator().currentTime() + schedulerTimeout;
lastCurrentEventTime = currentTime;
scheduler.notifyAt(lastScheduledTime);
}
}
<<<<<<<
=======
private void flushCurrentChunk(Processor nextProcessor, StreamEventCloner streamEventCloner, long currentTime) {
// need flush the currentEventChunk
currentEventChunk.reset();
ComplexEventChunk<StreamEvent> newEventChunk = new ComplexEventChunk<StreamEvent>();
// mark the timestamp for the expiredType event
while (expiredEventChunk.hasNext()) {
StreamEvent expiredEvent = expiredEventChunk.next();
expiredEvent.setTimestamp(currentTime);
}
// add expired event to newEventChunk too.
if (expiredEventChunk.getFirst() != null) {
newEventChunk.add(expiredEventChunk.getFirst());
}
// make current event chunk as expired in expiredChunk
expiredEventChunk.clear();
while (currentEventChunk.hasNext()) {
StreamEvent currentEvent = currentEventChunk.next();
StreamEvent toExpireEvent = streamEventCloner.copyStreamEvent(currentEvent);
toExpireEvent.setType(StreamEvent.Type.EXPIRED);
expiredEventChunk.add(toExpireEvent);
}
// add current event chunk to next processor
if (currentEventChunk.getFirst() != null) {
newEventChunk.add(currentEventChunk.getFirst());
}
currentEventChunk.clear();
endTime += timeToKeep;
if (newEventChunk.getFirst() != null) {
nextProcessor.process(newEventChunk);
}
}
>>>>>>> |
<<<<<<<
outputCallback = OutputParser.constructLocalOutputCallback(query.getOutputStream(), localStreamJunctionMap,
=======
outputCallback = OutputParser.constructOutputCallback(query.getOutputStream(), localStreamJunctionMap, eventTableMap,
>>>>>>>
outputCallback = OutputParser.constructLocalOutputCallback(query.getOutputStream(), localStreamJunctionMap, eventTableMap,
<<<<<<<
streamJunction = new StreamJunction(streamDefinition, executionPlanContext.getExecutorService(),
executionPlanContext.getSiddhiContext().getEventBufferSize(), executionPlanContext);
=======
StreamDefinition streamDefinition = (StreamDefinition) localStreamDefinitionMap.get("#" + streamId);
if (streamDefinition == null) {
streamDefinition = (StreamDefinition) streamDefinitionMap.get(streamId);
}
streamJunction = new StreamJunction(streamDefinition, executionPlanContext.getExecutorService(),
executionPlanContext.getSiddhiContext().getEventBufferSize(), executionPlanContext
);
>>>>>>>
StreamDefinition streamDefinition = (StreamDefinition) localStreamDefinitionMap.get("#" + streamId);
if (streamDefinition == null) {
streamDefinition = (StreamDefinition) streamDefinitionMap.get(streamId);
}
streamJunction = new StreamJunction(streamDefinition,executionPlanContext.getExecutorService(),
executionPlanContext.getSiddhiContext().getEventBufferSize(), executionPlanContext
);
<<<<<<<
/**
* define inner stream
*
* @param streamDefinition definition of an inner stream
*/
public void defineLocalStream(StreamDefinition streamDefinition) {
if (!checkEventStreamExist(streamDefinition, localStreamDefinitionMap)) {
localStreamDefinitionMap.put("#"+streamDefinition.getId(), streamDefinition);
StreamJunction streamJunction = localStreamJunctionMap.get(streamDefinition.getId());
if (streamJunction == null) {
streamJunction = new StreamJunction(streamDefinition,
executionPlanContext.getExecutorService(),
executionPlanContext.getSiddhiContext().getEventBufferSize(),executionPlanContext);
localStreamJunctionMap.putIfAbsent("#"+streamDefinition.getId(), streamJunction);
}
}
}
private boolean checkEventStreamExist(StreamDefinition newStreamDefinition, ConcurrentMap<String, AbstractDefinition> streamDefinitionMap) {
AbstractDefinition definition = streamDefinitionMap.get(newStreamDefinition.getId());
if (definition != null) {
if (definition instanceof TableDefinition) {
throw new DifferentDefinitionAlreadyExistException("Table " + newStreamDefinition.getId() + " is already defined as "
+ definition + ", hence cannot define " + newStreamDefinition);
} else if (!definition.getAttributeList().equals(newStreamDefinition.getAttributeList())) {
throw new DifferentDefinitionAlreadyExistException("Stream " + newStreamDefinition.getId() + " is already defined as "
+ definition + ", hence cannot define " + newStreamDefinition);
} else {
return true;
}
}
return false;
}
=======
>>>>>>>
/**
* define inner stream
*
* @param streamDefinition definition of an inner stream
*/
public void defineLocalStream(StreamDefinition streamDefinition) {
if (!checkEventStreamExist(streamDefinition, localStreamDefinitionMap)) {
localStreamDefinitionMap.put("#"+streamDefinition.getId(), streamDefinition);
StreamJunction streamJunction = localStreamJunctionMap.get(streamDefinition.getId());
if (streamJunction == null) {
streamJunction = new StreamJunction(streamDefinition,
executionPlanContext.getExecutorService(),
executionPlanContext.getSiddhiContext().getEventBufferSize(),executionPlanContext);
localStreamJunctionMap.putIfAbsent(streamDefinition.getId(), streamJunction);
}
}
}
private boolean checkEventStreamExist(StreamDefinition newStreamDefinition, ConcurrentMap<String, AbstractDefinition> streamDefinitionMap) {
AbstractDefinition definition = streamDefinitionMap.get(newStreamDefinition.getId());
if (definition != null) {
if (definition instanceof TableDefinition) {
throw new DifferentDefinitionAlreadyExistException("Table " + newStreamDefinition.getId() + " is already defined as "
+ definition + ", hence cannot define " + newStreamDefinition);
} else if (!definition.getAttributeList().equals(newStreamDefinition.getAttributeList())) {
throw new DifferentDefinitionAlreadyExistException("Stream " + newStreamDefinition.getId() + " is already defined as "
+ definition + ", hence cannot define " + newStreamDefinition);
} else {
return true;
}
}
return false;
} |
<<<<<<<
@Override
public Finder constructFinder(Expression expression, MatchingMetaStateHolder matchingMetaStateHolder, ExecutionPlanContext executionPlanContext,
List<VariableExpressionExecutor> variableExpressionExecutors, Map<String, EventTable> eventTableMap) {
return OperatorParser.constructOperator(expiredEventChunk, expression, matchingMetaStateHolder,executionPlanContext,variableExpressionExecutors,eventTableMap);
=======
public Finder constructFinder(Expression expression, MetaComplexEvent matchingMetaComplexEvent, ExecutionPlanContext executionPlanContext, List<VariableExpressionExecutor> variableExpressionExecutors, Map<String, EventTable> eventTableMap, int matchingStreamIndex, long withinTime) {
if (expiredEventChunk == null) {
expiredEventChunk = new ComplexEventChunk<StreamEvent>(false);
storeExpiredEvents = true;
}
return CollectionOperatorParser.parse(expression, matchingMetaComplexEvent, executionPlanContext, variableExpressionExecutors, eventTableMap, matchingStreamIndex, inputDefinition, withinTime);
>>>>>>>
@Override
public Finder constructFinder(Expression expression, MatchingMetaStateHolder matchingMetaStateHolder, ExecutionPlanContext executionPlanContext,
List<VariableExpressionExecutor> variableExpressionExecutors, Map<String, EventTable> eventTableMap) {
if (expiredEventChunk == null) {
expiredEventChunk = new ComplexEventChunk<StreamEvent>(false);
storeExpiredEvents = true;
}
return OperatorParser.constructOperator(expiredEventChunk, expression, matchingMetaStateHolder,executionPlanContext,variableExpressionExecutors,eventTableMap); |
<<<<<<<
"@from(eventtable = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "' , bloom.filters = 'enable') " +
=======
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "' , bloom.filters = 'enable') " +
>>>>>>>
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "' , bloom.filters = 'enable') " +
<<<<<<<
"@from(eventtable = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"define stream StockStream (symbol string, price float, volume long); " +
"define stream UpdateStockStream (symbol string, price float, volume long); " +
"@from(eventtable = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
"define table StockTable (symbol string, price float, volume long); ";
=======
"define stream StockStream (symbol string, price float, volume long); " +
"define stream UpdateStockStream (symbol string, price float, volume long); " +
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
"define table StockTable (symbol string, price float, volume long); ";
>>>>>>>
"define stream StockStream (symbol string, price float, volume long); " +
"define stream UpdateStockStream (symbol string, price float, volume long); " +
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
"define table StockTable (symbol string, price float, volume long); ";
<<<<<<<
"define stream StockStream (symbol string, price float, volume long); " +
"define stream UpdateStockStream (symbol string, price float, volume long); " +
"@from(eventtable = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
"define table StockTable (symbol string, price float, volume long); ";
=======
"define stream StockStream (symbol string, price float, volume long); " +
"define stream UpdateStockStream (symbol string, price float, volume long); " +
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
"define table StockTable (symbol string, price float, volume long); ";
>>>>>>>
"define stream StockStream (symbol string, price float, volume long); " +
"define stream UpdateStockStream (symbol string, price float, volume long); " +
"@from(table = 'rdbms' , datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "'" +
" , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
"define table StockTable (symbol string, price float, volume long); "; |
<<<<<<<
import java.time.Instant;
import java.time.temporal.ChronoUnit;
import java.util.List;
=======
import java.time.ZonedDateTime;
>>>>>>>
import java.time.Instant;
import java.time.temporal.ChronoUnit;
import java.util.List;
import java.time.ZonedDateTime; |
<<<<<<<
public static QuerySelector parse(Selector selector, OutputStream outputStream, ExecutionPlanContext
executionPlanContext,
MetaComplexEvent metaComplexEvent, Map<String, EventTable> eventTableMap,
List<VariableExpressionExecutor> variableExpressionExecutors, String queryName) {
=======
public static QuerySelector parse(Selector selector, OutputStream outputStream, ExecutionPlanContext executionPlanContext,
MetaComplexEvent metaComplexEvent, Map<String, Table> tableMap, List<VariableExpressionExecutor> variableExpressionExecutors, String queryName) {
>>>>>>>
public static QuerySelector parse(Selector selector, OutputStream outputStream, ExecutionPlanContext
executionPlanContext,
MetaComplexEvent metaComplexEvent, Map<String, Table> tableMap,
List<VariableExpressionExecutor> variableExpressionExecutors, String queryName) {
<<<<<<<
List<AttributeProcessor> attributeProcessors = getAttributeProcessors(selector, id, executionPlanContext,
metaComplexEvent, eventTableMap, variableExpressionExecutors, queryName);
querySelector.setAttributeProcessorList(attributeProcessors, "true".equals(containsAggregatorThreadLocal.get
()));
=======
List<AttributeProcessor> attributeProcessors = getAttributeProcessors(selector, id, executionPlanContext, metaComplexEvent, tableMap, variableExpressionExecutors, queryName);
querySelector.setAttributeProcessorList(attributeProcessors, "true".equals(containsAggregatorThreadLocal.get()));
>>>>>>>
List<AttributeProcessor> attributeProcessors = getAttributeProcessors(selector, id, executionPlanContext,
metaComplexEvent, tableMap, variableExpressionExecutors, queryName);
querySelector.setAttributeProcessorList(attributeProcessors, "true".equals(containsAggregatorThreadLocal.get
()));
<<<<<<<
Map<String, EventTable> eventTableMap,
List<VariableExpressionExecutor>
variableExpressionExecutors, String
queryName) {
=======
Map<String, Table> tableMap, List<VariableExpressionExecutor> variableExpressionExecutors, String queryName) {
>>>>>>>
Map<String, Table> tableMap,
List<VariableExpressionExecutor>
variableExpressionExecutors, String
queryName) {
<<<<<<<
metaComplexEvent, SiddhiConstants.UNKNOWN_STATE, eventTableMap, variableExpressionExecutors,
executionPlanContext,
=======
metaComplexEvent, SiddhiConstants.UNKNOWN_STATE, tableMap, variableExpressionExecutors, executionPlanContext,
>>>>>>>
metaComplexEvent, SiddhiConstants.UNKNOWN_STATE, tableMap, variableExpressionExecutors,
executionPlanContext,
<<<<<<<
Map<String, EventTable> eventTableMap,
List<VariableExpressionExecutor>
variableExpressionExecutors, String
queryName) {
=======
Map<String, Table> tableMap, List<VariableExpressionExecutor> variableExpressionExecutors, String queryName) {
>>>>>>>
Map<String, Table> tableMap,
List<VariableExpressionExecutor>
variableExpressionExecutors, String
queryName) {
<<<<<<<
metaComplexEvent, SiddhiConstants.HAVING_STATE, eventTableMap, variableExpressionExecutors,
executionPlanContext, false, 0, queryName);
=======
metaComplexEvent, SiddhiConstants.HAVING_STATE, tableMap, variableExpressionExecutors, executionPlanContext, false, 0, queryName);
>>>>>>>
metaComplexEvent, SiddhiConstants.HAVING_STATE, tableMap, variableExpressionExecutors,
executionPlanContext, false, 0, queryName); |
<<<<<<<
import org.wso2.siddhi.query.api.SiddhiApp;
=======
import org.wso2.siddhi.query.api.ExecutionPlan;
import org.wso2.siddhi.query.api.definition.AggregationDefinition;
>>>>>>>
import org.wso2.siddhi.query.api.SiddhiApp;
import org.wso2.siddhi.query.api.definition.AggregationDefinition; |
<<<<<<<
import org.testng.AssertJUnit;
import org.testng.annotations.BeforeMethod;
import org.testng.annotations.Test;
=======
import org.junit.Assert;
import org.junit.Test;
>>>>>>>
import org.testng.AssertJUnit;
import org.testng.annotations.Test;
<<<<<<<
private int inEventCount;
private int removeEventCount;
private boolean eventArrived;
private List<AssertionError> assertionErrors = new ArrayList<>();
@BeforeMethod
public void init() {
inEventCount = 0;
removeEventCount = 0;
eventArrived = false;
}
=======
>>>>>>>
<<<<<<<
for (AssertionError e : this.assertionErrors) {
throw e;
}
AssertJUnit.assertEquals("Number of success events", 1, inEventCount);
AssertJUnit.assertEquals("Number of remove events", 0, removeEventCount);
AssertJUnit.assertTrue("Event arrived", eventArrived);
=======
callback.throwAssertionErrors();
Assert.assertEquals("Number of success events", 1, callback.getInEventCount());
Assert.assertEquals("Number of remove events", 0, callback.getRemoveEventCount());
Assert.assertTrue("Event arrived", callback.isEventArrived());
>>>>>>>
callback.throwAssertionErrors();
AssertJUnit.assertEquals("Number of success events", 1, callback.getInEventCount());
AssertJUnit.assertEquals("Number of remove events", 0, callback.getRemoveEventCount());
AssertJUnit.assertTrue("Event arrived", callback.isEventArrived());
<<<<<<<
for (AssertionError e : this.assertionErrors) {
throw e;
}
AssertJUnit.assertEquals("Number of success events", 0, inEventCount);
AssertJUnit.assertEquals("Number of remove events", 0, removeEventCount);
AssertJUnit.assertFalse("Event arrived", eventArrived);
=======
callback.throwAssertionErrors();
Assert.assertEquals("Number of success events", 0, callback.getInEventCount());
Assert.assertEquals("Number of remove events", 0, callback.getRemoveEventCount());
Assert.assertFalse("Event arrived", callback.isEventArrived());
>>>>>>>
callback.throwAssertionErrors();
AssertJUnit.assertEquals("Number of success events", 0, callback.getInEventCount());
AssertJUnit.assertEquals("Number of remove events", 0, callback.getRemoveEventCount());
AssertJUnit.assertFalse("Event arrived", callback.isEventArrived()); |
<<<<<<<
@Test(expectedExceptions = SiddhiAppValidationException.class)
=======
@Test(expected = SiddhiAppCreationException.class)
>>>>>>>
@Test(expectedExceptions = SiddhiAppCreationException.class)
<<<<<<<
@Test(expectedExceptions = SiddhiAppValidationException.class)
=======
@Test(expected = SiddhiAppCreationException.class)
>>>>>>>
@Test(expectedExceptions = SiddhiAppCreationException.class)
<<<<<<<
@Test(expectedExceptions = SiddhiAppValidationException.class)
=======
@Test(expected = SiddhiAppCreationException.class)
>>>>>>>
@Test(expectedExceptions = SiddhiAppCreationException.class) |
<<<<<<<
private boolean isFirstEventArrived;
private long lastExecutorsRefreshedTime = -1;
=======
private IncrementalDataPurging incrementalDataPurging;
>>>>>>>
private boolean isFirstEventArrived;
private long lastExecutorsRefreshedTime = -1;
private IncrementalDataPurging incrementalDataPurging;
<<<<<<<
public void recreateInMemoryData(boolean isEventArrived) {
isFirstEventArrived = isEventArrived;
if (isEventArrived) {
for (Map.Entry<TimePeriod.Duration, IncrementalExecutor> durationIncrementalExecutorEntry :
this.incrementalExecutorMap.entrySet()) {
durationIncrementalExecutorEntry.getValue().setProcessingExecutor(isEventArrived);
}
}
recreateInMemoryData.recreateInMemoryData(isEventArrived);
}
public IncrementalExecutor getRootExecutor() {
return incrementalExecutorMap.get(incrementalDurations.get(0));
=======
public void start() {
recreateInMemoryData.recreateInMemoryData();
incrementalDataPurging.executeIncrementalDataPurging();
>>>>>>>
public void recreateInMemoryData(boolean isEventArrived) {
isFirstEventArrived = isEventArrived;
if (isEventArrived) {
for (Map.Entry<TimePeriod.Duration, IncrementalExecutor> durationIncrementalExecutorEntry :
this.incrementalExecutorMap.entrySet()) {
durationIncrementalExecutorEntry.getValue().setProcessingExecutor(isEventArrived);
}
incrementalDataPurging.executeIncrementalDataPurging();
}
recreateInMemoryData.recreateInMemoryData(isEventArrived);
}
public IncrementalExecutor getRootExecutor() {
return incrementalExecutorMap.get(incrementalDurations.get(0)); |
<<<<<<<
import org.wso2.siddhi.core.stream.input.source.InputTransport;
import org.wso2.siddhi.core.stream.output.sink.OutputTransport;
import org.wso2.siddhi.core.table.EventTable;
=======
import org.wso2.siddhi.core.stream.input.source.Source;
import org.wso2.siddhi.core.stream.output.sink.Sink;
import org.wso2.siddhi.core.table.Table;
>>>>>>>
import org.wso2.siddhi.core.stream.input.source.Source;
import org.wso2.siddhi.core.stream.output.sink.Sink;
import org.wso2.siddhi.core.table.Table;
<<<<<<<
executionPlanContext, streamDefinitionMap, tableDefinitionMap, windowDefinitionMap,
eventTableMap, eventWindowMap, executors, latencyTracker, outputExpectsExpiredEvents, queryName);
=======
executionPlanContext, streamDefinitionMap, tableDefinitionMap, windowDefinitionMap, tableMap, eventWindowMap, executors, latencyTracker, outputExpectsExpiredEvents, queryName);
>>>>>>>
executionPlanContext, streamDefinitionMap, tableDefinitionMap, windowDefinitionMap, tableMap, eventWindowMap, executors, latencyTracker, outputExpectsExpiredEvents, queryName);
<<<<<<<
// If at least one EventWindow is involved in the join, use the LockWrapper of that window
// for the query as well.
// If join is between two EventWindows, sync the locks of the LockWrapper of those windows
// and use either of them for query.
=======
// If at least one Window is involved in the join, use the LockWrapper of that window for the query as well.
// If join is between two EventWindows, sync the locks of the LockWrapper of those windows and use either of them for query.
>>>>>>>
// If at least one Window is involved in the join, use the LockWrapper of that window
// for the query as well.
// If join is between two EventWindows, sync the locks of the LockWrapper of those windows
// and use either of them for query.
<<<<<<<
// Join does not contain any EventWindow
lockWrapper = new LockWrapper(""); // Query LockWrapper does not need a unique id since
// it will not be passed to the LockSynchronizer.
=======
// Join does not contain any Window
lockWrapper = new LockWrapper(""); // Query LockWrapper does not need a unique id since it will not be passed to the LockSynchronizer.
>>>>>>>
// Join does not contain any Window
lockWrapper = new LockWrapper(""); // Query LockWrapper does not need a unique id since
// it will not be passed to the LockSynchronizer. |
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" + |
<<<<<<<
import org.testng.AssertJUnit;
import org.testng.annotations.BeforeMethod;
import org.testng.annotations.Test;
=======
import org.junit.Assert;
import org.junit.Test;
>>>>>>>
import org.testng.AssertJUnit;
import org.testng.annotations.Test;
<<<<<<<
private int inEventCount;
private int removeEventCount;
private boolean eventArrived;
private List<AssertionError> assertionErrors = new ArrayList<>();
@BeforeMethod
public void init() {
inEventCount = 0;
removeEventCount = 0;
eventArrived = false;
}
=======
>>>>>>>
<<<<<<<
for (AssertionError e : this.assertionErrors) {
throw e;
}
AssertJUnit.assertEquals("Number of success events", 2, inEventCount);
AssertJUnit.assertEquals("Number of remove events", 0, removeEventCount);
AssertJUnit.assertTrue("Event arrived", eventArrived);
=======
callback.throwAssertionErrors();
Assert.assertEquals("Number of success events", 2, callback.getInEventCount());
Assert.assertEquals("Number of remove events", 0, callback.getRemoveEventCount());
Assert.assertTrue("Event arrived", callback.isEventArrived());
>>>>>>>
callback.throwAssertionErrors();
AssertJUnit.assertEquals("Number of success events", 2, callback.getInEventCount());
AssertJUnit.assertEquals("Number of remove events", 0, callback.getRemoveEventCount());
AssertJUnit.assertTrue("Event arrived", callback.isEventArrived());
<<<<<<<
for (AssertionError e : this.assertionErrors) {
throw e;
}
AssertJUnit.assertEquals("Number of success events", 0, inEventCount);
AssertJUnit.assertEquals("Number of remove events", 0, removeEventCount);
AssertJUnit.assertFalse("Event arrived", eventArrived);
=======
callback.throwAssertionErrors();
Assert.assertEquals("Number of success events", 0, callback.getInEventCount());
Assert.assertEquals("Number of remove events", 0, callback.getRemoveEventCount());
Assert.assertFalse("Event arrived", callback.isEventArrived());
>>>>>>>
callback.throwAssertionErrors();
AssertJUnit.assertEquals("Number of success events", 0, callback.getInEventCount());
AssertJUnit.assertEquals("Number of remove events", 0, callback.getRemoveEventCount());
AssertJUnit.assertFalse("Event arrived", callback.isEventArrived());
<<<<<<<
for (AssertionError e : this.assertionErrors) {
throw e;
}
AssertJUnit.assertEquals("Number of success events", 2, inEventCount);
AssertJUnit.assertEquals("Number of remove events", 0, removeEventCount);
AssertJUnit.assertTrue("Event arrived", eventArrived);
=======
callback.throwAssertionErrors();
Assert.assertEquals("Number of success events", 2, callback.getInEventCount());
Assert.assertEquals("Number of remove events", 0, callback.getRemoveEventCount());
Assert.assertTrue("Event arrived", callback.isEventArrived());
>>>>>>>
callback.throwAssertionErrors();
AssertJUnit.assertEquals("Number of success events", 2, callback.getInEventCount());
AssertJUnit.assertEquals("Number of remove events", 0, callback.getRemoveEventCount());
AssertJUnit.assertTrue("Event arrived", callback.isEventArrived());
<<<<<<<
for (AssertionError e : this.assertionErrors) {
throw e;
}
AssertJUnit.assertEquals("Number of success events", 2, inEventCount);
AssertJUnit.assertEquals("Number of remove events", 0, removeEventCount);
AssertJUnit.assertTrue("Event arrived", eventArrived);
=======
callback.throwAssertionErrors();
Assert.assertEquals("Number of success events", 2, callback.getInEventCount());
Assert.assertEquals("Number of remove events", 0, callback.getRemoveEventCount());
Assert.assertTrue("Event arrived", callback.isEventArrived());
>>>>>>>
callback.throwAssertionErrors();
AssertJUnit.assertEquals("Number of success events", 2, callback.getInEventCount());
AssertJUnit.assertEquals("Number of remove events", 0, callback.getRemoveEventCount());
AssertJUnit.assertTrue("Event arrived", callback.isEventArrived());
<<<<<<<
for (AssertionError e : this.assertionErrors) {
throw e;
}
AssertJUnit.assertEquals("Number of success events", 0, inEventCount);
AssertJUnit.assertEquals("Number of remove events", 0, removeEventCount);
AssertJUnit.assertFalse("Event arrived", eventArrived);
=======
callback.throwAssertionErrors();
Assert.assertEquals("Number of success events", 0, callback.getInEventCount());
Assert.assertEquals("Number of remove events", 0, callback.getRemoveEventCount());
Assert.assertFalse("Event arrived", callback.isEventArrived());
>>>>>>>
callback.throwAssertionErrors();
AssertJUnit.assertEquals("Number of success events", 0, callback.getInEventCount());
AssertJUnit.assertEquals("Number of remove events", 0, callback.getRemoveEventCount());
AssertJUnit.assertFalse("Event arrived", callback.isEventArrived()); |
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "' , bloom.filters = 'enable') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "' , bloom.filters = 'enable') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "' , bloom.filters = 'enable') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "', cache='lfu', cache.size='1000') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "', cache='lfu', cache.size='1000') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "', cache='lfu', cache.size='1000') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "', bloom.filters = 'enable') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "', bloom.filters = 'enable') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "', bloom.filters = 'enable') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "', bloom.filters = 'enable') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "', bloom.filters = 'enable') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "', bloom.filters = 'enable') " + |
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" + |
<<<<<<<
import io.sphere.sdk.annotations.ResourceValue;
=======
import io.sphere.sdk.annotations.HasByIdGetEndpoint;
import io.sphere.sdk.annotations.HasQueryEndpoint;
import io.sphere.sdk.annotations.ResourceInfo;
>>>>>>>
import io.sphere.sdk.annotations.ResourceValue;
import io.sphere.sdk.annotations.HasByIdGetEndpoint;
import io.sphere.sdk.annotations.HasQueryEndpoint;
import io.sphere.sdk.annotations.ResourceInfo;
<<<<<<<
@ResourceValue
=======
@HasQueryEndpoint(additionalContentsQueryInterface = "\n" +
" default ZoneQuery byName(final String name) {\n" +
" return withPredicates(m -> m.name().is(name));\n" +
" }\n" +
"\n" +
" /**\n" +
" * Predicate which matches the country of a location, does not take the state into the consideration.\n" +
" * For considering also the state use {@link #byLocation(io.sphere.sdk.zones.Location)}.\n" +
" * @param countryCode the country to query for\n" +
" * @return query with the same values but a predicate searching for a specific country\n" +
" */\n" +
" default ZoneQuery byCountry(final CountryCode countryCode) {\n" +
" return withPredicates(m -> m.locations().country().is(countryCode));\n" +
" }\n" +
"\n" +
" /**\n" +
" * Predicate which matches the country and state of a location.\n" +
" *\n" +
" * For ignoring the state use {@link #byCountry(com.neovisionaries.i18n.CountryCode)}.\n" +
" * @param location the location to query for\n" +
" * @return query with the same values but a predicate searching for a specific location\n" +
" */\n" +
" default ZoneQuery byLocation(final Location location) {\n" +
" final QueryPredicate<Zone> predicate =\n" +
" Optional.ofNullable(location.getState())\n" +
" .map(state -> ZoneQueryModel.of().locations().where(l -> l.country().is(location.getCountry()).and(l.state().is(state))))\n" +
" .orElseGet(() -> ZoneQueryModel.of().locations().where(l -> l.country().is(location.getCountry()).and(l.state().isNotPresent())));\n" +
" return withPredicates(predicate);\n" +
" }")
@ResourceInfo(pluralName = "zones", pathElement = "zones", commonImports = {
"com.neovisionaries.i18n.CountryCode",
"io.sphere.sdk.zones.Location"
})
@HasByIdGetEndpoint(javadocSummary = "Gets a zone by ID.", includeExamples = "io.sphere.sdk.zones.queries.ZoneByIdGetIntegrationTest#fetchById()")
>>>>>>>
@ResourceValue
@HasQueryEndpoint(additionalContentsQueryInterface = "\n" +
" default ZoneQuery byName(final String name) {\n" +
" return withPredicates(m -> m.name().is(name));\n" +
" }\n" +
"\n" +
" /**\n" +
" * Predicate which matches the country of a location, does not take the state into the consideration.\n" +
" * For considering also the state use {@link #byLocation(io.sphere.sdk.zones.Location)}.\n" +
" * @param countryCode the country to query for\n" +
" * @return query with the same values but a predicate searching for a specific country\n" +
" */\n" +
" default ZoneQuery byCountry(final CountryCode countryCode) {\n" +
" return withPredicates(m -> m.locations().country().is(countryCode));\n" +
" }\n" +
"\n" +
" /**\n" +
" * Predicate which matches the country and state of a location.\n" +
" *\n" +
" * For ignoring the state use {@link #byCountry(com.neovisionaries.i18n.CountryCode)}.\n" +
" * @param location the location to query for\n" +
" * @return query with the same values but a predicate searching for a specific location\n" +
" */\n" +
" default ZoneQuery byLocation(final Location location) {\n" +
" final QueryPredicate<Zone> predicate =\n" +
" Optional.ofNullable(location.getState())\n" +
" .map(state -> ZoneQueryModel.of().locations().where(l -> l.country().is(location.getCountry()).and(l.state().is(state))))\n" +
" .orElseGet(() -> ZoneQueryModel.of().locations().where(l -> l.country().is(location.getCountry()).and(l.state().isNotPresent())));\n" +
" return withPredicates(predicate);\n" +
" }")
@ResourceInfo(pluralName = "zones", pathElement = "zones", commonImports = {
"com.neovisionaries.i18n.CountryCode",
"io.sphere.sdk.zones.Location"
})
@HasByIdGetEndpoint(javadocSummary = "Gets a zone by ID.", includeExamples = "io.sphere.sdk.zones.queries.ZoneByIdGetIntegrationTest#fetchById()") |
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "', cache='lru', cache.size='1000') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "', cache='lru', cache.size='1000') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "', cache='lru', cache.size='1000') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = 'table2') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = 'table2') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = 'table2') " +
<<<<<<<
"@from(eventtable = 'rdbms' , jdbc.url = 'jdbc:mysql://localhost:3306/cepdb' , username = " +
"'root' , password = 'root' , driver.name = 'com.mysql.jdbc.Driver' , table.name = '" +
RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' , jdbc.url = 'jdbc:mysql://localhost:3306/cepdb' , username = 'root' , password = 'root' , driver.name = 'com.mysql.jdbc.Driver' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' , jdbc.url = 'jdbc:mysql://localhost:3306/cepdb' , username = " +
"'root' , password = 'root' , driver.name = 'com.mysql.jdbc.Driver' , table.name = '" +
RDBMSTestConstants.TABLE_NAME + "') " + |
<<<<<<<
import org.wso2.siddhi.core.util.transport.DynamicOptions;
=======
import org.wso2.siddhi.core.util.transport.BackoffRetryCounter;
import org.wso2.siddhi.core.util.transport.DynamicOptions;
>>>>>>>
import org.wso2.siddhi.core.util.transport.BackoffRetryCounter;
import org.wso2.siddhi.core.util.transport.DynamicOptions;
<<<<<<<
sinkMapper.init(streamDefinition, mapType, mapOptionHolder, payload, this,
mapperConfigReader, siddhiAppContext);
=======
sinkMapper.init(streamDefinition, mapType, mapOptionHolder, payload, mapperConfigReader, siddhiAppContext);
>>>>>>>
sinkMapper.init(streamDefinition, mapType, mapOptionHolder, payload, this,
mapperConfigReader, siddhiAppContext);
<<<<<<<
void setTrpDynamicOptions(ThreadLocal<DynamicOptions> trpDynamicOptions) {
this.trpDynamicOptions = trpDynamicOptions;
}
=======
public StreamDefinition getStreamDefinition() {
return streamDefinition;
}
>>>>>>>
void setTrpDynamicOptions(ThreadLocal<DynamicOptions> trpDynamicOptions) {
this.trpDynamicOptions = trpDynamicOptions;
}
public StreamDefinition getStreamDefinition() {
return streamDefinition;
} |
<<<<<<<
/*
* Copyright (C) 2012-2019 52°North Initiative for Geospatial Open Source
=======
/**
* Copyright (C) 2012-2020 52°North Initiative for Geospatial Open Source
>>>>>>>
/*
* Copyright (C) 2012-2020 52°North Initiative for Geospatial Open Source |
<<<<<<<
EventWindow eventWindow = eventWindowMap.get(singleInputStream.getStreamId());
boolean batchProcessingAllowed = eventWindow != null; // If stream is from window, allow batch
// processing
ProcessStreamReceiver processStreamReceiver = new ProcessStreamReceiver(singleInputStream.getStreamId(),
latencyTracker, queryName);
=======
Window window = eventWindowMap.get(singleInputStream.getStreamId());
boolean batchProcessingAllowed = window != null; // If stream is from window, allow batch processing
ProcessStreamReceiver processStreamReceiver = new ProcessStreamReceiver(singleInputStream.getStreamId(), latencyTracker, queryName);
>>>>>>>
Window window = eventWindowMap.get(singleInputStream.getStreamId());
boolean batchProcessingAllowed = window != null; // If stream is from window, allow batch
// processing
ProcessStreamReceiver processStreamReceiver = new ProcessStreamReceiver(singleInputStream.getStreamId(),
latencyTracker, queryName);
<<<<<<<
executionPlanContext, executors, streamDefinitionMap, null, windowDefinitionMap, eventTableMap,
new MetaStreamEvent(), processStreamReceiver, true, outputExpectsExpiredEvents, queryName);
=======
executionPlanContext, executors, streamDefinitionMap, null, windowDefinitionMap, tableMap, new MetaStreamEvent(), processStreamReceiver, true, outputExpectsExpiredEvents, queryName);
>>>>>>>
executionPlanContext, executors, streamDefinitionMap, null, windowDefinitionMap, tableMap,
new MetaStreamEvent(), processStreamReceiver, true, outputExpectsExpiredEvents, queryName);
<<<<<<<
return JoinInputStreamParser.parseInputStream(((JoinInputStream) inputStream), executionPlanContext,
streamDefinitionMap, tableDefinitionMap, windowDefinitionMap, eventTableMap, eventWindowMap,
executors, latencyTracker, outputExpectsExpiredEvents, queryName);
=======
return JoinInputStreamParser.parseInputStream(((JoinInputStream) inputStream), executionPlanContext, streamDefinitionMap, tableDefinitionMap, windowDefinitionMap, tableMap, eventWindowMap, executors, latencyTracker, outputExpectsExpiredEvents, queryName);
>>>>>>>
return JoinInputStreamParser.parseInputStream(((JoinInputStream) inputStream), executionPlanContext,
streamDefinitionMap, tableDefinitionMap, windowDefinitionMap, tableMap, eventWindowMap,
executors, latencyTracker, outputExpectsExpiredEvents, queryName);
<<<<<<<
metaStateEvent, streamDefinitionMap, null, null, eventTableMap, executors, latencyTracker,
queryName);
=======
metaStateEvent, streamDefinitionMap, null, null, tableMap, executors, latencyTracker, queryName);
>>>>>>>
metaStateEvent, streamDefinitionMap, null, null, tableMap, executors, latencyTracker,
queryName); |
<<<<<<<
description = "In-memory transport that can communicate with other in-memory transports within the same JVM, " +
"it " +
=======
description = "In-memory source that can communicate with other in-memory sinks within the same JVM, it " +
>>>>>>>
description = "In-memory source that can communicate with other in-memory sinks within the same JVM, " +
"it " + |
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "', cache='lru', cache.size='1000') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "', cache='lru', cache.size='1000') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "', cache='lru', cache.size='1000') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "', cache='lru', cache.size='1000') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "', cache='lru', cache.size='1000') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "', cache='lru', cache.size='1000') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "' , bloom.filters = 'enable') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "' , bloom.filters = 'enable') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "' , bloom.filters = 'enable') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "' , bloom.filters = 'enable') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "' , bloom.filters = 'enable') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "' , bloom.filters = 'enable') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
=======
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
>>>>>>>
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
<<<<<<<
"define stream StockStream (symbol string, price float, volume long); " +
"define stream UpdateStockStream (symbol string, price float, volume long); " +
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
"define table StockTable (symbol string, price float, volume long); ";
=======
"define stream StockStream (symbol string, price float, volume long); " +
"define stream UpdateStockStream (symbol string, price float, volume long); " +
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
"define table StockTable (symbol string, price float, volume long); ";
>>>>>>>
"define stream StockStream (symbol string, price float, volume long); " +
"define stream UpdateStockStream (symbol string, price float, volume long); " +
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
"define table StockTable (symbol string, price float, volume long); ";
<<<<<<<
"define stream StockStream (symbol string, price float, volume long); " +
"define stream UpdateStockStream (symbol string, price float, volume long); " +
"@from(eventtable = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
"define table StockTable (symbol string, price float, volume long); ";
=======
"define stream StockStream (symbol string, price float, volume long); " +
"define stream UpdateStockStream (symbol string, price float, volume long); " +
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' , table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
"define table StockTable (symbol string, price float, volume long); ";
>>>>>>>
"define stream StockStream (symbol string, price float, volume long); " +
"define stream UpdateStockStream (symbol string, price float, volume long); " +
"@from(table = 'rdbms' ,datasource.name = '" + RDBMSTestConstants.DATA_SOURCE_NAME + "' " +
", table.name = '" + RDBMSTestConstants.TABLE_NAME + "') " +
"define table StockTable (symbol string, price float, volume long); "; |
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
<<<<<<<
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" +
//"@PrimaryKey(\"symbol\")" +
//"@Index(\"volume\")" +
=======
"@Store(type=\"testWithCache\", @Cache(size=\"10\"))\n" +
>>>>>>>
"@Store(type=\"testStoreContainingInMemoryTable\", @Cache(size=\"10\"))\n" + |
<<<<<<<
import java.util.concurrent.ScheduledExecutorService;
import java.util.concurrent.TimeUnit;
=======
import java.util.concurrent.locks.ReadWriteLock;
import java.util.concurrent.locks.ReentrantReadWriteLock;
>>>>>>>
import java.util.concurrent.locks.ReadWriteLock;
import java.util.concurrent.locks.ReentrantReadWriteLock;
import java.util.concurrent.ScheduledExecutorService;
import java.util.concurrent.TimeUnit;
<<<<<<<
private int currentCacheSize = 0;
private int cacheMode = CACHE_MODE_BASIC_PRELOAD;
private long cacheExpiryCheckIntervalInMillis;
private boolean cacheEnabled = false;
private boolean cacheExpiryEnabled = false;
private InMemoryTable cacheTable;
=======
private InMemoryTable cachedTable;
private boolean isCacheEnabled = false;
>>>>>>>
private int cacheMode = CACHE_MODE_BASIC_PRELOAD;
private long cacheExpiryCheckIntervalInMillis;
private boolean cacheEnabled = false;
private boolean cacheExpiryEnabled = false;
private InMemoryTable cacheTable;
<<<<<<<
protected SiddhiAppContext siddhiAppContext;
private CacheExpiryHandlerRunnable cacheExpiryHandlerRunnable;
private ScheduledExecutorService scheduledExecutorServiceForCacheExpiry;
protected StateEvent findMatchingEvent;
protected Selector selectorForTestStoreQuery;
protected SiddhiQueryContext siddhiQueryContextForTestStoreQuery;
protected MatchingMetaInfoHolder matchingMetaInfoHolderForTestStoreQuery;
protected StateEvent containsMatchingEvent;
=======
private SiddhiAppContext siddhiAppContext;
private ReadWriteLock readWriteLock = new ReentrantReadWriteLock();
>>>>>>>
protected SiddhiAppContext siddhiAppContext;
private CacheExpiryHandlerRunnable cacheExpiryHandlerRunnable;
private ScheduledExecutorService scheduledExecutorServiceForCacheExpiry;
protected StateEvent findMatchingEvent;
protected Selector selectorForTestStoreQuery;
protected SiddhiQueryContext siddhiQueryContextForTestStoreQuery;
protected MatchingMetaInfoHolder matchingMetaInfoHolderForTestStoreQuery;
protected StateEvent containsMatchingEvent;
private ReadWriteLock readWriteLock = new ReentrantReadWriteLock();
<<<<<<<
cacheTable = new InMemoryTable();
cacheTableDefinition = generateCacheTableDefinition(tableDefinition);
if (cacheTableAnnotation.getElement(ANNOTATION_CACHE_EXPIRY_TIME) != null) {
cacheExpiryEnabled = true;
cacheTableDefinition.attribute(CACHE_TABLE_TIMESTAMP, Attribute.Type.LONG);
long cacheExpirationTimeInMillis = Expression.Time.timeToLong(cacheTableAnnotation.
getElement(ANNOTATION_CACHE_EXPIRY_TIME));
cacheExpiryCheckIntervalInMillis = Expression.Time.timeToLong(cacheTableAnnotation.
getElement(ANNOTATION_CACHE_EXPIRY_CHECK_INTERVAL));
MetaStreamEvent cacheTableMetaStreamEvent = new MetaStreamEvent();
cacheTableMetaStreamEvent.addInputDefinition(cacheTableDefinition);
for (Attribute attribute : cacheTableDefinition.getAttributeList()) {
cacheTableMetaStreamEvent.addOutputData(attribute);
=======
cachedTable = new InMemoryTable();
cacheTableDefinition = TableDefinition.id(tableDefinition.getId());
for (Attribute attribute: tableDefinition.getAttributeList()) {
cacheTableDefinition.attribute(attribute.getName(), attribute.getType());
}
for (Annotation annotation: tableDefinition.getAnnotations()) {
if (!annotation.getName().equalsIgnoreCase("Store")) {
cacheTableDefinition.annotation(annotation);
>>>>>>>
cacheTable = new InMemoryTable();
cacheTableDefinition = TableDefinition.id(tableDefinition.getId());
for (Attribute attribute: tableDefinition.getAttributeList()) {
cacheTableDefinition.attribute(attribute.getName(), attribute.getType());
}
for (Annotation annotation: tableDefinition.getAnnotations()) {
if (!annotation.getName().equalsIgnoreCase("Store")) {
cacheTableDefinition.annotation(annotation);
}
}
if (cacheTableAnnotation.getElement(ANNOTATION_CACHE_EXPIRY_TIME) != null) {
cacheExpiryEnabled = true;
cacheTableDefinition.attribute(CACHE_TABLE_TIMESTAMP, Attribute.Type.LONG);
long cacheExpirationTimeInMillis = Expression.Time.timeToLong(cacheTableAnnotation.
getElement(ANNOTATION_CACHE_EXPIRY_TIME));
cacheExpiryCheckIntervalInMillis = Expression.Time.timeToLong(cacheTableAnnotation.
getElement(ANNOTATION_CACHE_EXPIRY_CHECK_INTERVAL));
MetaStreamEvent cacheTableMetaStreamEvent = new MetaStreamEvent();
cacheTableMetaStreamEvent.addInputDefinition(cacheTableDefinition);
for (Attribute attribute : cacheTableDefinition.getAttributeList()) {
cacheTableMetaStreamEvent.addOutputData(attribute);
<<<<<<<
=======
cachedTable.initTable(cacheTableDefinition, storeEventPool,
storeEventCloner, configReader, siddhiAppContext, recordTableHandler);
>>>>>>>
<<<<<<<
cacheTable.addEvents(loadedCache, preLoadedDataSize);
currentCacheSize = preLoadedDataSize;
=======
cachedTable.addEvents(loadedCache, preLoadedDataSize);
>>>>>>>
cacheTable.addEvents(loadedCache, preLoadedDataSize);
<<<<<<<
public StreamEvent findInCache(CompiledCondition compiledCondition, StateEvent matchingEvent) {
if (cacheEnabled) {
return cacheTable.find(matchingEvent, compiledCondition);
} else {
return null;
}
}
private Object[] appendValue(Object[] obj, Object newObj) {
ArrayList<Object> temp = new ArrayList<Object>(Arrays.asList(obj));
temp.add(newObj);
return temp.toArray();
}
=======
>>>>>>>
<<<<<<<
findMatchingEvent = matchingEvent;
if (cacheEnabled) {
=======
CompiledConditionWithCache compiledConditionAggregation = null;
if (isCacheEnabled) {
>>>>>>>
CompiledConditionWithCache compiledConditionAggregation = null;
findMatchingEvent = matchingEvent;
if (cacheEnabled) { |
<<<<<<<
this.addTest(canSnoozeAndDismissEvent("Can snooze/dismiss event", true));
=======
this.addTest(canGetReminderView("Can get reminderView()", true));
>>>>>>>
this.addTest(canSnoozeAndDismissEvent("Can snooze/dismiss event", true));
this.addTest(canGetReminderView("Can get reminderView()", true)); |
<<<<<<<
import scala.reflect.ClassTag;
import scala.reflect.ClassTag$;
=======
import scala.reflect.ClassManifest;
import scala.reflect.ClassManifest$;
>>>>>>>
import scala.reflect.ClassTag;
import scala.reflect.ClassTag$;
<<<<<<<
public abstract Tuple2<K, V> call(T t) throws Exception;
public ClassTag<K> keyType() {
return (ClassTag<K>) ClassTag$.MODULE$.apply(Object.class);
=======
public ClassManifest<K> keyType() {
return (ClassManifest<K>) ClassManifest$.MODULE$.fromClass(Object.class);
>>>>>>>
public ClassTag<K> keyType() {
return (ClassTag<K>) ClassTag$.MODULE$.apply(Object.class); |
<<<<<<<
properties = {"server.servlet.contextPath: /app", "zuul.host.socket-timeout-millis=11000",
"zuul.host.connect-timeout-millis=2100"})
=======
properties = {"server.contextPath: /app"})
>>>>>>>
properties = {"server.servlet.contextPath: /app"}) |
<<<<<<<
import java.nio.charset.Charset;
import java.util.ArrayList;
=======
import static org.hamcrest.Matchers.is;
import static org.junit.Assert.assertEquals;
import static org.junit.Assert.assertFalse;
import static org.junit.Assume.assumeThat;
>>>>>>>
import static org.hamcrest.Matchers.is;
import static org.junit.Assert.assertEquals;
import static org.junit.Assert.assertFalse;
import static org.junit.Assume.assumeThat;
import java.nio.charset.Charset;
import java.util.ArrayList; |
<<<<<<<
.withConfiguration(AutoConfigurations.of(RefreshAutoConfiguration.class))
.withUserConfiguration(Beans.class).run(c -> {
assertThat(c).hasSingleBean(
org.springframework.cloud.context.scope.refresh.RefreshScope.class);
assertThat(c.getBean("foo")).isEqualTo("foo");
});
=======
.withConfiguration(AutoConfigurations.of(RefreshAutoConfiguration.class))
.withUserConfiguration(Beans.class).run(c -> {
assertThat(c).hasSingleBean(
org.springframework.cloud.context.scope.refresh.RefreshScope.class);
assertThat(c.getBean("foo")).isEqualTo("foo");
assertThat(c).doesNotHaveBean("bar");
});
}
@Test
public void refreshScopeIncludedAndPropertyDisabled() {
new ApplicationContextRunner()
.withConfiguration(AutoConfigurations.of(RefreshAutoConfiguration.class))
.withPropertyValues("eureka.client.refresh.enable=false")
.withUserConfiguration(Beans.class).run(c -> {
assertThat(c).hasSingleBean(
org.springframework.cloud.context.scope.refresh.RefreshScope.class);
assertThat(c).doesNotHaveBean("foo");
assertThat(c.getBean("bar")).isEqualTo("bar");
});
>>>>>>>
.withConfiguration(AutoConfigurations.of(RefreshAutoConfiguration.class))
.withUserConfiguration(Beans.class).run(c -> {
assertThat(c).hasSingleBean(
org.springframework.cloud.context.scope.refresh.RefreshScope.class);
assertThat(c.getBean("foo")).isEqualTo("foo");
});
}
@Test
public void refreshScopeIncludedAndPropertyDisabled() {
new ApplicationContextRunner()
.withConfiguration(AutoConfigurations.of(RefreshAutoConfiguration.class))
.withPropertyValues("eureka.client.refresh.enable=false")
.withUserConfiguration(Beans.class).run(c -> {
assertThat(c).hasSingleBean(
org.springframework.cloud.context.scope.refresh.RefreshScope.class);
assertThat(c).doesNotHaveBean("foo");
assertThat(c.getBean("bar")).isEqualTo("bar");
});
<<<<<<<
=======
@Bean
@ConditionalOnMissingRefreshScope
public String bar() {
return "bar";
}
>>>>>>>
@Bean
@ConditionalOnMissingRefreshScope
public String bar() {
return "bar";
} |
<<<<<<<
import org.apache.http.client.HttpClient;
import org.apache.http.client.config.RequestConfig;
import org.apache.http.config.RegistryBuilder;
import org.apache.http.conn.HttpClientConnectionManager;
import org.apache.http.impl.client.CloseableHttpClient;
import org.springframework.beans.factory.annotation.Autowired;
=======
>>>>>>>
<<<<<<<
import org.springframework.boot.autoconfigure.condition.ConditionalOnProperty;
import org.springframework.boot.context.properties.EnableConfigurationProperties;
=======
>>>>>>>
import org.springframework.boot.context.properties.EnableConfigurationProperties;
<<<<<<<
import feign.httpclient.ApacheHttpClient;
import feign.okhttp.OkHttpClient;
import okhttp3.ConnectionPool;
import java.util.Timer;
import java.util.TimerTask;
import java.util.concurrent.TimeUnit;
import javax.annotation.PreDestroy;
=======
>>>>>>>
<<<<<<<
@EnableConfigurationProperties({ FeignHttpClientProperties.class })
=======
//Order is important here, last should be the default, first should be optional
// see https://github.com/spring-cloud/spring-cloud-netflix/issues/2086#issuecomment-316281653
@Import({ HttpClientFeignLoadBalancedConfiguration.class,
OkHttpFeignLoadBalancedConfiguration.class,
DefaultFeignLoadBalancedConfiguration.class })
>>>>>>>
@EnableConfigurationProperties({ FeignHttpClientProperties.class })
//Order is important here, last should be the default, first should be optional
// see https://github.com/spring-cloud/spring-cloud-netflix/issues/2086#issuecomment-316281653
@Import({ HttpClientFeignLoadBalancedConfiguration.class,
OkHttpFeignLoadBalancedConfiguration.class,
DefaultFeignLoadBalancedConfiguration.class })
<<<<<<<
public Client feignClient(CachingSpringLoadBalancerFactory cachingFactory,
SpringClientFactory clientFactory) {
return new LoadBalancerFeignClient(new Client.Default(null, null), cachingFactory,
clientFactory);
}
@Bean
@ConditionalOnMissingBean
=======
>>>>>>> |
<<<<<<<
public InstanceInfo sendHeartBeat(@PathVariable String appName,
@PathVariable String id, @RequestParam String status,
@RequestParam String lastDirtyTimestamp,
@RequestParam(required = false) String overriddenstatus) {
return new InstanceInfo(null, null, null, null, null, null, null, null, null,
null, null, null, null, 0, null, null, null, null, null, null, null, new HashMap<String, String>(), 0l,
0l, null, null);
=======
public ResponseEntity sendHeartBeat(@PathVariable String appName,
@PathVariable String id, @RequestParam String status,
@RequestParam String lastDirtyTimestamp,
@RequestParam(required = false) String overriddenstatus) {
if("fourOFour".equals(appName)) {
return new ResponseEntity(HttpStatus.NOT_FOUND);
}
return new ResponseEntity<InstanceInfo>(new InstanceInfo(null, null, null, null, null, null, null, null, null,
null, null, null, null, 0, null, null, null, null, null, null, null, 0l,
0l, null, null), HttpStatus.OK);
>>>>>>>
public ResponseEntity sendHeartBeat(@PathVariable String appName,
@PathVariable String id, @RequestParam String status,
@RequestParam String lastDirtyTimestamp,
@RequestParam(required = false) String overriddenstatus) {
if("fourOFour".equals(appName)) {
return new ResponseEntity(HttpStatus.NOT_FOUND);
}
return new ResponseEntity<InstanceInfo>(new InstanceInfo(null, null, null, null, null, null, null, null, null,
null, null, null, null, 0, null, null, null, null, null, null, null, new HashMap<String, String>(), 0l,
0l, null, null), HttpStatus.OK); |
<<<<<<<
=======
import org.springframework.boot.actuate.health.HealthIndicatorRegistryFactory;
import org.springframework.boot.actuate.health.ReactiveHealthIndicator;
>>>>>>>
import org.springframework.boot.actuate.health.ReactiveHealthIndicator;
<<<<<<<
private Map<String, HealthIndicator> healthIndicators = new HashMap<>();
=======
private Map<String, HealthIndicator> healthIndicators;
private Map<String, ReactiveHealthIndicator> reactiveHealthIndicators = new HashMap<>();
@Deprecated
private CompositeHealthIndicator healthIndicator;
@Deprecated
private HealthIndicatorRegistryFactory healthIndicatorRegistryFactory;
@Deprecated
private HealthAggregator healthAggregator;
@Deprecated
public EurekaHealthCheckHandler(HealthAggregator healthAggregator) {
Assert.notNull(healthAggregator, "HealthAggregator must not be null");
this.healthAggregator = healthAggregator;
this.healthIndicatorRegistryFactory = new HealthIndicatorRegistryFactory();
this.healthIndicator = new CompositeHealthIndicator(this.healthAggregator,
new DefaultHealthIndicatorRegistry());
}
>>>>>>>
private Map<String, HealthIndicator> healthIndicators = new HashMap<>();
private Map<String, ReactiveHealthIndicator> reactiveHealthIndicators = new HashMap<>();
<<<<<<<
final Map<String, HealthIndicator> healthIndicators = applicationContext.getBeansOfType(HealthIndicator.class);
=======
final Map<String, HealthIndicator> healthIndicators = applicationContext
.getBeansOfType(HealthIndicator.class);
this.healthIndicators = new HashMap<>();
final Map<String, ReactiveHealthIndicator> reactiveHealthIndicators = applicationContext
.getBeansOfType(ReactiveHealthIndicator.class);
if (statusAggregator != null) {
populateHealthIndicators(healthIndicators);
populateReactiveHealthIndicators(reactiveHealthIndicators);
}
else {
createHealthIndicator(healthIndicators);
}
}
@Deprecated
void createHealthIndicator(Map<String, HealthIndicator> healthIndicators) {
for (Map.Entry<String, HealthIndicator> entry : healthIndicators.entrySet()) {
// ignore EurekaHealthIndicator and flatten the rest of the composite
// otherwise there is a never ending cycle of down. See gh-643
if (entry.getValue() instanceof DiscoveryCompositeHealthIndicator) {
DiscoveryCompositeHealthIndicator indicator = (DiscoveryCompositeHealthIndicator) entry
.getValue();
for (DiscoveryCompositeHealthIndicator.Holder holder : indicator
.getHealthIndicators()) {
if (!(holder.getDelegate() instanceof EurekaHealthIndicator)) {
this.healthIndicators.put(holder.getDelegate().getName(), holder);
}
}
>>>>>>>
this.applicationContext = applicationContext;
}
@Override
public void afterPropertiesSet() {
final Map<String, HealthIndicator> healthIndicators = applicationContext.getBeansOfType(HealthIndicator.class);
final Map<String, ReactiveHealthIndicator> reactiveHealthIndicators = applicationContext
.getBeansOfType(ReactiveHealthIndicator.class);
<<<<<<<
Set<Status> statusSet = healthIndicators.values().stream().map(HealthIndicator::health).map(Health::getStatus)
.collect(Collectors.toSet());
=======
Set<Status> statusSet = new HashSet<>();
if (healthIndicators != null) {
statusSet.addAll(
healthIndicators.values().stream().map(HealthIndicator::health)
.map(Health::getStatus).collect(Collectors.toSet()));
}
if (reactiveHealthIndicators != null) {
statusSet.addAll(reactiveHealthIndicators.values().stream()
.map(ReactiveHealthIndicator::health).map(health -> {
return health.block().getStatus();
}).collect(Collectors.toSet()));
}
>>>>>>>
Set<Status> statusSet = new HashSet<>();
if (healthIndicators != null) {
statusSet.addAll(healthIndicators.values().stream().map(HealthIndicator::health).map(Health::getStatus)
.collect(Collectors.toSet()));
}
if (reactiveHealthIndicators != null) {
statusSet.addAll(reactiveHealthIndicators.values().stream().map(ReactiveHealthIndicator::health)
.map(health -> health.block().getStatus()).collect(Collectors.toSet()));
} |
<<<<<<<
@ConditionalOnClass(name = "org.springframework.web.client.RestTemplate")
=======
@ConfigurationProperties("eureka.client.tls")
public TlsProperties tlsProperties() {
return new TlsProperties();
}
@Bean
>>>>>>>
@ConfigurationProperties("eureka.client.tls")
public TlsProperties tlsProperties() {
return new TlsProperties();
}
@Bean
@ConditionalOnClass(name = "org.springframework.web.client.RestTemplate")
<<<<<<<
public MutableDiscoveryClientOptionalArgs discoveryClientOptionalArgs() {
logger.info("Eureka Client uses Jersey");
return new MutableDiscoveryClientOptionalArgs();
=======
public MutableDiscoveryClientOptionalArgs discoveryClientOptionalArgs(
TlsProperties tlsProperties) throws GeneralSecurityException, IOException {
logger.info("Eureka HTTP Client uses Jersey");
MutableDiscoveryClientOptionalArgs result = new MutableDiscoveryClientOptionalArgs();
setupTLS(result, tlsProperties);
return result;
}
private static void setupTLS(AbstractDiscoveryClientOptionalArgs<?> args,
TlsProperties properties) throws GeneralSecurityException, IOException {
if (properties.isEnabled()) {
SSLContextFactory factory = new SSLContextFactory(properties);
args.setSSLContext(factory.createSSLContext());
}
>>>>>>>
public MutableDiscoveryClientOptionalArgs discoveryClientOptionalArgs(
TlsProperties tlsProperties) throws GeneralSecurityException, IOException {
logger.info("Eureka HTTP Client uses Jersey");
MutableDiscoveryClientOptionalArgs result = new MutableDiscoveryClientOptionalArgs();
setupTLS(result, tlsProperties);
return result;
}
private static void setupTLS(AbstractDiscoveryClientOptionalArgs<?> args,
TlsProperties properties) throws GeneralSecurityException, IOException {
if (properties.isEnabled()) {
SSLContextFactory factory = new SSLContextFactory(properties);
args.setSSLContext(factory.createSSLContext());
} |
<<<<<<<
import org.springframework.boot.actuate.health.SimpleStatusAggregator;
=======
import org.springframework.boot.actuate.health.OrderedHealthAggregator;
import org.springframework.boot.actuate.health.ReactiveHealthIndicator;
import org.springframework.boot.actuate.health.SimpleStatusAggregator;
>>>>>>>
import org.springframework.boot.actuate.health.ReactiveHealthIndicator;
import org.springframework.boot.actuate.health.SimpleStatusAggregator; |
<<<<<<<
public EurekaInstanceConfigBean eurekaInstanceConfigBean(InetUtils inetUtils) {
String hostname = getProperty("eureka.instance.hostname");
boolean preferIpAddress = Boolean.parseBoolean(getProperty("eureka.instance.prefer-ip-address"));
=======
public EurekaInstanceConfigBean eurekaInstanceConfigBean(InetUtils inetUtils) throws MalformedURLException {
PropertyResolver eurekaPropertyResolver = new RelaxedPropertyResolver(this.env, "eureka.instance.");
String hostname = eurekaPropertyResolver.getProperty("hostname");
boolean preferIpAddress = Boolean.parseBoolean(eurekaPropertyResolver.getProperty("preferIpAddress"));
int nonSecurePort = Integer.valueOf(propertyResolver.getProperty("server.port", propertyResolver.getProperty("port", "8080")));
int managementPort = Integer.valueOf(propertyResolver.getProperty("management.port", String.valueOf(nonSecurePort)));
String managementContextPath = propertyResolver.getProperty("management.contextPath", propertyResolver.getProperty("server.contextPath", "/"));
>>>>>>>
public EurekaInstanceConfigBean eurekaInstanceConfigBean(InetUtils inetUtils) {
String hostname = getProperty("eureka.instance.hostname");
boolean preferIpAddress = Boolean.parseBoolean(getProperty("eureka.instance.prefer-ip-address"));
int nonSecurePort = Integer.valueOf(env.getProperty("server.port", env.getProperty("port", "8080")));
int managementPort = Integer.valueOf(env.getProperty("management.port", String.valueOf(nonSecurePort)));
String managementContextPath = env.getProperty("management.context-path", env.getProperty("server.servlet.context-path", "/"));
<<<<<<<
String statusPageUrlPath = getProperty("eureka.instance.status-page-url-path");
String healthCheckUrlPath = getProperty("eureka.instance.health-check-url-path");
=======
String statusPageUrlPath = eurekaPropertyResolver.getProperty("statusPageUrlPath");
String healthCheckUrlPath = eurekaPropertyResolver.getProperty("healthCheckUrlPath");
if (!managementContextPath.endsWith("/")) {
managementContextPath = managementContextPath + "/";
}
>>>>>>>
String statusPageUrlPath = getProperty("eureka.instance.status-page-url-path");
String healthCheckUrlPath = getProperty("eureka.instance.health-check-url-path");
if (!managementContextPath.endsWith("/")) {
managementContextPath = managementContextPath + "/";
} |
<<<<<<<
import org.springframework.cloud.client.loadbalancer.LoadBalancedBackOffPolicyFactory;
import org.springframework.cloud.client.loadbalancer.LoadBalancedRetryListenerFactory;
import org.springframework.cloud.client.loadbalancer.LoadBalancedRetryPolicyFactory;
=======
import org.springframework.cloud.client.loadbalancer.LoadBalancedRetryFactory;
>>>>>>>
import org.springframework.cloud.client.loadbalancer.LoadBalancedRetryFactory;
<<<<<<<
import org.springframework.cloud.netflix.ribbon.RibbonLoadBalancedRetryPolicy;
import org.springframework.cloud.netflix.ribbon.RibbonLoadBalancedRetryPolicyFactory;
import org.springframework.cloud.netflix.ribbon.RibbonLoadBalancerContext;
import org.springframework.cloud.netflix.ribbon.ServerIntrospector;
import org.springframework.cloud.netflix.ribbon.SpringClientFactory;
=======
import org.springframework.cloud.netflix.ribbon.RibbonLoadBalancedRetryFactory;
>>>>>>>
import org.springframework.cloud.netflix.ribbon.RibbonLoadBalancedRetryFactory;
import org.springframework.cloud.netflix.ribbon.RibbonLoadBalancedRetryPolicy;
import org.springframework.cloud.netflix.ribbon.RibbonLoadBalancerContext;
import org.springframework.cloud.netflix.ribbon.ServerIntrospector;
import org.springframework.cloud.netflix.ribbon.SpringClientFactory; |
<<<<<<<
if (SupportUtil.nonShowRationale(this)) {
boolean androidPage = getPageType() == Permissions4M.PageType
.ANDROID_SETTING_PAGE;
Intent intent = androidPage ? PermissionsPageManager.getSettingIntent(activity) :
PermissionsPageManager.getIntent(activity);
proxy.intent(getContext(), getRequestCode(), intent);
}
=======
proxy.granted(activity, requestCode);
>>>>>>>
if (SupportUtil.nonShowRationale(this)) {
boolean androidPage = getPageType() == Permissions4M.PageType
.ANDROID_SETTING_PAGE;
Intent intent = androidPage ? PermissionsPageManager.getSettingIntent(activity) :
PermissionsPageManager.getIntent(activity);
proxy.intent(getContext(), getRequestCode(), intent);
}
proxy.granted(activity, requestCode); |
<<<<<<<
private CardType type;
private int length;
private String mHelperText;
public SecurityCodeText(Context context) {
super(context);
init();
}
public SecurityCodeText(Context context, AttributeSet attrs) {
super(context, attrs);
init();
}
public SecurityCodeText(Context context, AttributeSet attrs, int defStyle) {
super(context, attrs, defStyle);
init();
}
void init() {
super.init();
setHint("CVV");
}
/* TextWatcher Implementation Methods */
public void beforeTextChanged(CharSequence s, int start, int count, int after) {
}
public void afterTextChanged(Editable s) {
if (type == null) {
=======
private CardType type;
private int length;
public SecurityCodeText(Context context) {
super(context);
init();
}
public SecurityCodeText(Context context, AttributeSet attrs) {
super(context, attrs);
init();
}
public SecurityCodeText(Context context, AttributeSet attrs, int defStyle) {
super(context, attrs, defStyle);
init();
}
void init() {
super.init();
setHint("CVV");
}
/* TextWatcher Implementation Methods */
public void beforeTextChanged(CharSequence s, int start, int count, int after) {}
public void afterTextChanged(Editable s) {
if(type == null) {
>>>>>>>
private CardType type;
private int length;
private String mHelperText;
public SecurityCodeText(Context context) {
super(context);
init();
}
public SecurityCodeText(Context context, AttributeSet attrs) {
super(context, attrs);
init();
}
public SecurityCodeText(Context context, AttributeSet attrs, int defStyle) {
super(context, attrs, defStyle);
init();
}
void init() {
super.init();
setHint("CVV");
}
/* TextWatcher Implementation Methods */
public void beforeTextChanged(CharSequence s, int start, int count, int after) {}
public void afterTextChanged(Editable s) {
if(type == null) {
<<<<<<<
if (type != null) {
String number = s.toString();
if (number.length() == length) {
setValid(true);
delegate.onSecurityCodeValid();
} else {
setValid(false);
}
}
}
@SuppressWarnings("unused")
public CardType getType() {
return type;
}
public void setType(CardType type) {
this.type = type;
this.length = CreditCardUtil.securityCodeValid(type);
setFilters(new InputFilter[]{new InputFilter.LengthFilter(length)});
}
@Override
public void setHelperText(String helperText) {
mHelperText = helperText;
}
@Override
public String getHelperText() {
return (mHelperText != null ? mHelperText : context.getString(R.string.SecurityCodeHelp));
}
}
=======
if (type != null) {
if (s.length() >= length) {
setValid(true);
String remainder = null;
if(s.length() > length()) remainder = String.valueOf(s).substring(length);
this.removeTextChangedListener(this);
setText(String.valueOf(s).substring(0, length));
this.addTextChangedListener(this);
delegate.onSecurityCodeValid(remainder);
} else {
setValid(false);
}
}
}
@SuppressWarnings("unused")
public CardType getType() {
return type;
}
public void setType(CardType type) {
this.type = type;
this.length = CreditCardUtil.securityCodeValid(type);
}
@Override
public String helperText() {
return context.getString(R.string.SecurityCodeHelp);
}
}
>>>>>>>
if (type != null) {
if (s.length() >= length) {
setValid(true);
String remainder = null;
if(s.length() > length()) remainder = String.valueOf(s).substring(length);
this.removeTextChangedListener(this);
setText(String.valueOf(s).substring(0, length));
this.addTextChangedListener(this);
delegate.onSecurityCodeValid(remainder);
} else {
setValid(false);
}
}
}
@SuppressWarnings("unused")
public CardType getType() {
return type;
}
public void setType(CardType type) {
this.type = type;
this.length = CreditCardUtil.securityCodeValid(type);
}
@Override
public void setHelperText(String helperText) {
mHelperText = helperText;
}
@Override
public String getHelperText() {
return (mHelperText != null ? mHelperText : context.getString(R.string.SecurityCodeHelp));
}
} |
<<<<<<<
=======
int updateOrderStatusAndAmount(Map<String, Object> paramMap);
Integer getCampusIdByTogetherId(Map<String, Object> paramMap);
Float getPriceDiscounted(String[] orderId,int campusId,String phoneId);
Integer cancelOrderWithRefund(Map<String, Object> paramMap);
>>>>>>>
int updateOrderStatusAndAmount(Map<String, Object> paramMap);
Integer getCampusIdByTogetherId(Map<String, Object> paramMap);
Float getPriceDiscounted(String[] orderId,int campusId,String phoneId);
Integer cancelOrderWithRefund(Map<String, Object> paramMap); |
<<<<<<<
import java.text.ParseException;
import java.text.SimpleDateFormat;
import java.util.Calendar;
import java.util.Date;
=======
>>>>>>>
import java.text.ParseException;
import java.text.SimpleDateFormat;
import java.util.Date; |
<<<<<<<
Float selectTotalPriceByTogetherId(@Param(value="togetherId")String togetherId);
=======
int updateOrderStatusAndAmount(Map<String, Object> paramMap); //支付成功后更新订单和价格
Integer getCampusIdByTogetherId(Map<String, Object> paramMap); //获取某笔订单的校区号
CartGood getOrderByOrderId(Map<String, Object> paramMap); //获取某笔小订单
Integer cancelOrderWithRefund(Map<String, Object> paramMap);
>>>>>>>
Float selectTotalPriceByTogetherId(@Param(value="togetherId")String togetherId);
int updateOrderStatusAndAmount(Map<String, Object> paramMap); //支付成功后更新订单和价格
Integer getCampusIdByTogetherId(Map<String, Object> paramMap); //获取某笔订单的校区号
CartGood getOrderByOrderId(Map<String, Object> paramMap); //获取某笔小订单
Integer cancelOrderWithRefund(Map<String, Object> paramMap); |
<<<<<<<
=======
if (normalizeNamespaces) {
writer = new StrippingStreamWriterDelegate(writer);
}
>>>>>>> |
<<<<<<<
/*
* Default is 72 hours (3 days). The default SSL connection timeout is 24 hours, but
* session data can remain active after that period and persist across multiple
* connections.
*/
session.setMaxInactiveInterval(configurationController.getMaxInactiveSessionInterval());
loginStatus = userController.authorizeUser(username, password);
=======
>>>>>>>
/*
* Default is 72 hours (3 days). The default SSL connection timeout is 24 hours, but
* session data can remain active after that period and persist across multiple
* connections.
*/
session.setMaxInactiveInterval(configurationController.getMaxInactiveSessionInterval()); |
<<<<<<<
import com.mirth.connect.model.DashboardChannelInfo;
import com.mirth.connect.model.DashboardStatus;
import com.mirth.connect.model.DashboardStatus.StatusType;
=======
import com.mirth.connect.model.ServerEvent;
import com.mirth.connect.model.ServerEvent.Level;
import com.mirth.connect.model.ServerEvent.Outcome;
>>>>>>>
import com.mirth.connect.model.DashboardChannelInfo;
import com.mirth.connect.model.DashboardStatus;
import com.mirth.connect.model.DashboardStatus.StatusType;
import com.mirth.connect.model.ServerEvent;
import com.mirth.connect.model.ServerEvent.Level;
import com.mirth.connect.model.ServerEvent.Outcome;
<<<<<<<
} else if (exampleRequested.equals("channel_group_list")) {
requestedObject = getChannelGroupListExample();
} else if (exampleRequested.equals("channel_statistics")) {
requestedObject = getChannelStatisticsExample();
} else if (exampleRequested.equals("channel_statistics_list")) {
requestedObject = getChannelStatisticsListExample();
} else if (exampleRequested.equals("connector_map")) {
requestedObject = getConnectorMap(true);
} else if (exampleRequested.equals("start_connector_map")) {
requestedObject = getConnectorMap(false);
=======
} else if (exampleRequested.equals("connection_log_item_linked_list")) {
requestedObject = getConnectionLogItemLinkedListExample();
>>>>>>>
} else if (exampleRequested.equals("channel_group_list")) {
requestedObject = getChannelGroupListExample();
} else if (exampleRequested.equals("channel_statistics")) {
requestedObject = getChannelStatisticsExample();
} else if (exampleRequested.equals("channel_statistics_list")) {
requestedObject = getChannelStatisticsListExample();
} else if (exampleRequested.equals("connector_map")) {
requestedObject = getConnectorMap(true);
} else if (exampleRequested.equals("start_connector_map")) {
requestedObject = getConnectorMap(false);
} else if (exampleRequested.equals("connection_log_item_linked_list")) {
requestedObject = getConnectionLogItemLinkedListExample();
<<<<<<<
} else if (exampleRequested.equals("dashboard_channel_info")) {
requestedObject = getDashboardChannelInfoExample();
} else if (exampleRequested.equals("dashboard_status")) {
requestedObject = getDashboardStatusExample();
} else if (exampleRequested.equals("dashboard_status_list")) {
requestedObject = getDashboardStatusListExample();
} else if (exampleRequested.equals("guid_to_name_map")) {
=======
} else if (exampleRequested.equals("dashboard_channel_state_map")) {
requestedObject = getDashboardChannelStateMapExample();
} else if (exampleRequested.equals("dashboard_connector_state_map")) {
requestedObject = getDashboardConnectorStateMapExample();
} else if (exampleRequested.equals("data_pruner_status_map")) {
requestedObject = getDataPrunerStatusMapExample();
} else if (exampleRequested.equals("event_filter")) {
requestedObject = getEventFilterExample();
} else if (exampleRequested.equals("guid_to_name_map")) {
>>>>>>>
} else if (exampleRequested.equals("dashboard_channel_info")) {
requestedObject = getDashboardChannelInfoExample();
} else if (exampleRequested.equals("dashboard_status")) {
requestedObject = getDashboardStatusExample();
} else if (exampleRequested.equals("dashboard_status_list")) {
requestedObject = getDashboardStatusListExample();
} else if (exampleRequested.equals("dashboard_channel_state_map")) {
requestedObject = getDashboardChannelStateMapExample();
} else if (exampleRequested.equals("dashboard_connector_state_map")) {
requestedObject = getDashboardConnectorStateMapExample();
} else if (exampleRequested.equals("data_pruner_status_map")) {
requestedObject = getDataPrunerStatusMapExample();
} else if (exampleRequested.equals("event_filter")) {
requestedObject = getEventFilterExample();
} else if (exampleRequested.equals("guid_to_name_map")) {
<<<<<<<
private Map<String, List<Integer>> getConnectorMap(boolean includeNull) {
Map<String, List<Integer>> connectorMap = new HashMap<>();
List<Integer> connectorList = new ArrayList<>();
if (includeNull) {
connectorList.add(null); // channel stats
}
connectorList.add(0); // source connector stats
connectorList.add(1); // destination 1 connector stats
connectorMap.put(UUID.randomUUID().toString(), connectorList);
return connectorMap;
}
=======
private ConnectionLogItem getConnectionLogItemExample() {
ConnectionLogItem logItem = new ConnectionLogItem(1L, UUID.randomUUID().toString(), UUID.randomUUID().toString(), 0L, dateFormat.format(dateNow.getTime()), "Channel 1", "Source: Channel Reader (HL7V2 -> JSON)", "Idle", "");
return logItem;
}
private LinkedList<ConnectionLogItem> getConnectionLogItemLinkedListExample() {
LinkedList<ConnectionLogItem> logItems = new LinkedList<>();
logItems.add(getConnectionLogItemExample());
return logItems;
}
>>>>>>>
private Map<String, List<Integer>> getConnectorMap(boolean includeNull) {
Map<String, List<Integer>> connectorMap = new HashMap<>();
List<Integer> connectorList = new ArrayList<>();
if (includeNull) {
connectorList.add(null); // channel stats
}
connectorList.add(0); // source connector stats
connectorList.add(1); // destination 1 connector stats
connectorMap.put(UUID.randomUUID().toString(), connectorList);
return connectorMap;
}
private ConnectionLogItem getConnectionLogItemExample() {
ConnectionLogItem logItem = new ConnectionLogItem(1L, UUID.randomUUID().toString(), UUID.randomUUID().toString(), 0L, dateFormat.format(dateNow.getTime()), "Channel 1", "Source: Channel Reader (HL7V2 -> JSON)", "Idle", "");
return logItem;
}
private LinkedList<ConnectionLogItem> getConnectionLogItemLinkedListExample() {
LinkedList<ConnectionLogItem> logItems = new LinkedList<>();
logItems.add(getConnectionLogItemExample());
return logItems;
}
<<<<<<<
private DashboardChannelInfo getDashboardChannelInfoExample() {
DashboardChannelInfo dashboardChannelInfo = new DashboardChannelInfo(getDashboardStatusListExample(), getGuidSetExample(), 0);
return dashboardChannelInfo;
}
private DashboardStatus getDashboardStatusExample() {
DashboardStatus status = new DashboardStatus();
Map<Status, Long> statistics = new LinkedHashMap<>();
for (Status s: Status.values()) {
statistics.put(s, 0L);
}
status.setChannelId(UUID.randomUUID().toString());
status.setDeployedDate(dateNow);
status.setDeployedRevisionDelta(0);
status.setLifetimeStatistics(statistics);
status.setMetaDataId(0);
status.setName("Channel Name");
status.setQueueEnabled(false);
status.setQueued(0L);
status.setState(DeployedState.STARTED);
status.setStatistics(statistics);
status.setStatusType(StatusType.CHANNEL);
status.setWaitForPrevious(false);
return status;
}
private List<DashboardStatus> getDashboardStatusListExample() {
List<DashboardStatus> statusList = new ArrayList<>();
statusList.add(getDashboardStatusExample());
return statusList;
}
=======
private Map<String, String> getDashboardChannelStateMapExample() {
Map<String, String> stateMap = new HashMap<>();
stateMap.put(UUID.randomUUID().toString(), "Idle");
return stateMap;
}
private Map<String, Object[]> getDashboardConnectorStateMapExample() {
Map<String, Object[]> stateMap = new HashMap<>();
String channelId = UUID.randomUUID().toString();
Object[] states = new Object[2];
states[0] = new Color(255, 255, 0, 255);
states[1] = "Idle";
stateMap.put(channelId + "_0", states);
stateMap.put(channelId + "_1", states);
return stateMap;
}
private Map<String, String> getDataPrunerStatusMapExample() {
Map<String, String> statusMap = new HashMap<>();
statusMap.put("lastProcess", "-");
statusMap.put("isRunning", "false");
statusMap.put("currentState", "Not running");
statusMap.put("nextProcess", "Scheduled Monday, Jan 1, 1:00:00 AM");
statusMap.put("currentProcess", "-");
return statusMap;
}
private EventFilter getEventFilterExample() {
EventFilter eventFilter = new EventFilter();
eventFilter.setMaxEventId(2);
eventFilter.setMinEventId(1);
eventFilter.setId(1);
Set<Level> levels = new HashSet<>();
levels.add(Level.INFORMATION);
eventFilter.setLevels(levels);
eventFilter.setStartDate(dateNow);
eventFilter.setEndDate(dateTomorrow);
eventFilter.setOutcome(Outcome.SUCCESS);
eventFilter.setUserId(1);
eventFilter.setIpAddress("0:0:0:0:0:0:0:1");
eventFilter.setServerId(UUID.randomUUID().toString());
return eventFilter;
}
>>>>>>>
private DashboardChannelInfo getDashboardChannelInfoExample() {
DashboardChannelInfo dashboardChannelInfo = new DashboardChannelInfo(getDashboardStatusListExample(), getGuidSetExample(), 0);
return dashboardChannelInfo;
}
private DashboardStatus getDashboardStatusExample() {
DashboardStatus status = new DashboardStatus();
Map<Status, Long> statistics = new LinkedHashMap<>();
for (Status s: Status.values()) {
statistics.put(s, 0L);
}
status.setChannelId(UUID.randomUUID().toString());
status.setDeployedDate(dateNow);
status.setDeployedRevisionDelta(0);
status.setLifetimeStatistics(statistics);
status.setMetaDataId(0);
status.setName("Channel Name");
status.setQueueEnabled(false);
status.setQueued(0L);
status.setState(DeployedState.STARTED);
status.setStatistics(statistics);
status.setStatusType(StatusType.CHANNEL);
status.setWaitForPrevious(false);
return status;
}
private List<DashboardStatus> getDashboardStatusListExample() {
List<DashboardStatus> statusList = new ArrayList<>();
statusList.add(getDashboardStatusExample());
return statusList;
}
private Map<String, String> getDashboardChannelStateMapExample() {
Map<String, String> stateMap = new HashMap<>();
stateMap.put(UUID.randomUUID().toString(), "Idle");
return stateMap;
}
private Map<String, Object[]> getDashboardConnectorStateMapExample() {
Map<String, Object[]> stateMap = new HashMap<>();
String channelId = UUID.randomUUID().toString();
Object[] states = new Object[2];
states[0] = new Color(255, 255, 0, 255);
states[1] = "Idle";
stateMap.put(channelId + "_0", states);
stateMap.put(channelId + "_1", states);
return stateMap;
}
private Map<String, String> getDataPrunerStatusMapExample() {
Map<String, String> statusMap = new HashMap<>();
statusMap.put("lastProcess", "-");
statusMap.put("isRunning", "false");
statusMap.put("currentState", "Not running");
statusMap.put("nextProcess", "Scheduled Monday, Jan 1, 1:00:00 AM");
statusMap.put("currentProcess", "-");
return statusMap;
}
private EventFilter getEventFilterExample() {
EventFilter eventFilter = new EventFilter();
eventFilter.setMaxEventId(2);
eventFilter.setMinEventId(1);
eventFilter.setId(1);
Set<Level> levels = new HashSet<>();
levels.add(Level.INFORMATION);
eventFilter.setLevels(levels);
eventFilter.setStartDate(dateNow);
eventFilter.setEndDate(dateTomorrow);
eventFilter.setOutcome(Outcome.SUCCESS);
eventFilter.setUserId(1);
eventFilter.setIpAddress("0:0:0:0:0:0:0:1");
eventFilter.setServerId(UUID.randomUUID().toString());
return eventFilter;
} |
<<<<<<<
import com.amazonaws.services.s3.model.ObjectMetadata;
import com.amazonaws.services.s3.model.PutObjectRequest;
import com.amazonaws.services.s3.model.S3Object;
import com.amazonaws.services.s3.model.S3ObjectInputStream;
=======
import com.amazonaws.services.s3.model.S3Object;
>>>>>>>
import com.amazonaws.services.s3.model.ObjectMetadata;
import com.amazonaws.services.s3.model.PutObjectRequest;
import com.amazonaws.services.s3.model.S3Object;
import com.amazonaws.services.s3.model.S3ObjectInputStream;
<<<<<<<
// S3 doesn't allow appending
=======
>>>>>>>
// S3 doesn't allow appending |
<<<<<<<
import java.util.Optional;
=======
import static java.util.stream.Collectors.toList;
>>>>>>>
import static java.util.stream.Collectors.toList;
import java.util.Optional;
<<<<<<<
import org.cryptomator.jni.JniModule;
import org.cryptomator.jni.MacFunctions;
=======
import org.cryptomator.ui.model.Vault;
>>>>>>>
import org.cryptomator.jni.JniModule;
import org.cryptomator.jni.MacFunctions;
import org.cryptomator.ui.model.Vault;
<<<<<<<
@Provides
@Singleton
Optional<MacFunctions> provideMacFunctions() {
return JniModule.macFunctions();
}
=======
private void setValidFrontendIds(WebDavServer webDavServer, Vaults vaults) {
webDavServer.setValidFrontendIds(vaults.stream() //
.map(Vault::getId)
.map(FrontendId::from)
.collect(toList()));
}
>>>>>>>
@Provides
@Singleton
Optional<MacFunctions> provideMacFunctions() {
return JniModule.macFunctions();
}
private void setValidFrontendIds(WebDavServer webDavServer, Vaults vaults) {
webDavServer.setValidFrontendIds(vaults.stream() //
.map(Vault::getId).map(FrontendId::from).collect(toList()));
} |
<<<<<<<
useOwnMountPath.setSelected(vaultSettings.usesIndividualMountPath().get());
useReadOnlyMode.setSelected(vaultSettings.usesReadOnlyMode().get());
=======
if (!settings.preferredVolumeImpl().get().equals(VolumeImpl.WEBDAV)) {
useCustomMountPoint.setSelected(vaultSettings.usesIndividualMountPath().get());
customMountPointField.textProperty().setValue(vaultSettings.individualMountPath().getValueSafe());
}
>>>>>>>
useReadOnlyMode.setSelected(vaultSettings.usesReadOnlyMode().get());
if (!settings.preferredVolumeImpl().get().equals(VolumeImpl.WEBDAV)) {
useCustomMountPoint.setSelected(vaultSettings.usesIndividualMountPath().get());
customMountPointField.textProperty().setValue(vaultSettings.individualMountPath().getValueSafe());
}
<<<<<<<
vaultSubs = vaultSubs.and(EasyBind.subscribe(useOwnMountPath.selectedProperty(), vaultSettings.usesIndividualMountPath()::set));
vaultSubs = vaultSubs.and(EasyBind.subscribe(useReadOnlyMode.selectedProperty(), vaultSettings.usesReadOnlyMode()::set));
mountPath.textProperty().setValue(vaultSettings.individualMountPath().getValueSafe());
=======
vaultSubs = vaultSubs.and(EasyBind.subscribe(useCustomMountPoint.selectedProperty(), vaultSettings.usesIndividualMountPath()::set));
>>>>>>>
vaultSubs = vaultSubs.and(EasyBind.subscribe(useCustomMountPoint.selectedProperty(), vaultSettings.usesIndividualMountPath()::set));
vaultSubs = vaultSubs.and(EasyBind.subscribe(useReadOnlyMode.selectedProperty(), vaultSettings.usesReadOnlyMode()::set)); |
<<<<<<<
private final Provider<LockComponent.Builder> lockWindowBuilderProvider;
private final Provider<QuitComponent.Builder> quitWindowBuilderProvider;
=======
>>>>>>>
private final Provider<LockComponent.Builder> lockWindowBuilderProvider;
<<<<<<<
FxApplication(Settings settings, Lazy<MainWindowComponent> mainWindow, Lazy<PreferencesComponent> preferencesWindow, Provider<UnlockComponent.Builder> unlockWindowBuilderProvider, Provider<LockComponent.Builder> lockWindowBuilderProvider, Provider<QuitComponent.Builder> quitWindowBuilderProvider, Optional<TrayIntegrationProvider> trayIntegration, Optional<UiAppearanceProvider> appearanceProvider, VaultService vaultService, LicenseHolder licenseHolder, ObservableSet<Stage> visibleStages) {
=======
FxApplication(Settings settings, Lazy<MainWindowComponent> mainWindow, Lazy<PreferencesComponent> preferencesWindow, Provider<UnlockComponent.Builder> unlockWindowBuilderProvider, Lazy<QuitComponent> quitWindow, Optional<TrayIntegrationProvider> trayIntegration, Optional<UiAppearanceProvider> appearanceProvider, VaultService vaultService, LicenseHolder licenseHolder, ObservableSet<Stage> visibleStages) {
>>>>>>>
FxApplication(Settings settings, Lazy<MainWindowComponent> mainWindow, Lazy<PreferencesComponent> preferencesWindow, Provider<UnlockComponent.Builder> unlockWindowBuilderProvider, Provider<LockComponent.Builder> lockWindowBuilderProvider, Lazy<QuitComponent> quitWindow, Optional<TrayIntegrationProvider> trayIntegration, Optional<UiAppearanceProvider> appearanceProvider, VaultService vaultService, LicenseHolder licenseHolder, ObservableSet<Stage> visibleStages) {
<<<<<<<
this.lockWindowBuilderProvider = lockWindowBuilderProvider;
this.quitWindowBuilderProvider = quitWindowBuilderProvider;
=======
this.quitWindow = quitWindow;
>>>>>>>
this.lockWindowBuilderProvider = lockWindowBuilderProvider;
this.quitWindow = quitWindow; |
<<<<<<<
else if(PlatformDescription.isThisJVM(PlatformDescription.DALVIK)) {
return new AndroidInstantiator(type);
=======
else if(JVM_NAME.startsWith(DALVIK)) {
// System property "java.vm.version" seems to be 1.4.0 for Android 2.3 and 1.5.0 for Android 3.0
// so we use it here to choose the relevant implementation.
if(VENDOR_VERSION.compareTo("1.5.0") < 0) {
// Android 2.3 Gingerbread and lower
return new Android23Instantiator(type);
} else {
// Android 3.0 Honeycomb and higher
return new Android30Instantiator(type);
}
>>>>>>>
else if(PlatformDescription.isThisJVM(PlatformDescription.DALVIK)) {
// System property "java.vm.version" seems to be 1.4.0 for Android 2.3 and 1.5.0 for Android 3.0
// so we use it here to choose the relevant implementation.
if(VENDOR_VERSION.compareTo("1.5.0") < 0) {
// Android 2.3 Gingerbread and lower
return new Android23Instantiator(type);
} else {
// Android 3.0 Honeycomb and higher
return new Android30Instantiator(type);
} |
<<<<<<<
=======
>>>>>>>
<<<<<<<
if (f.isStatic()) {
System.out.println("static field name: " + f.getName());
org.llvm.Value v = l.getModule().addGlobal(f.llvmType(),
f.getOwner() + "." + f.getName());
l.setNamedValue(f.getOwner() + "." + f.getName(), v);
//
// Problems with initializers. The following are two approaches for setting
// the global initializer.
//
// Global variable initializer type does not match global variable type!
// %Hint* @TestObj.h
//
// For the line below. Using zeroinitializer instead of null (almost) works (using 2nd example)
// @TestObj.h = global %Hint null
// v.setInitializer(f.getType().defaultValue());
// This approach uses zeroinitializer. --LVVM output still complains but the llvm-as will take the
// assembly listing and compile it without complaint?
//org.llvm.Value init = TypeRef.structTypeNamed(f.getName()).constNull();
//v.setInitializer(init);
// set the gcroot for this var for later garbage collection
//org.llvm.Value res = b.buildBitCast(l.getNamedValue(f.getOwner() + "." + f.getName()), TypeRef.int8Type().pointerType().pointerType(), "gctmp");
//org.llvm.Value meta = TypeRef.int8Type().pointerType().constNull(); // TODO: replace with type data
//org.llvm.Value [] args = {res, meta};
//org.llvm.Value gc = b.buildCall(l.getGCRoot(), "", args);
=======
if (f.isStatic()) {
org.llvm.Value v = f.getStaticField();
v.setInitializer(f.llvmTypeField().constNull());
if (f.getInitExpr() != null) {
l.getBuilder().buildStore(f.getInitExpr().llvmGen(l), v);
}
>>>>>>>
if (f.isStatic()) {
org.llvm.Value v = f.getStaticField();
v.setInitializer(f.llvmTypeField().constNull());
if (f.getInitExpr() != null) {
l.getBuilder().buildStore(f.getInitExpr().llvmGen(l), v);
}
// set the gcroot for this var for later garbage collection
//System.out.println("static field name: " + f.getName());
//org.llvm.Value res = b.buildBitCast(l.getNamedValue(f.getOwner() + "." + f.getName()), TypeRef.int8Type().pointerType().pointerType(), "gctmp");
//org.llvm.Value meta = TypeRef.int8Type().pointerType().constNull(); // TODO: replace with type data
//org.llvm.Value [] args = {res, meta};
//org.llvm.Value gc = b.buildCall(l.getGCRoot(), "", args); |
<<<<<<<
logger.warn("Error while closing the connection: {}", e.getMessage());
if (logger.isDebugEnabled()) {
logger.warn("Full stacktrace", e);
}
=======
logger.warn("Error while closing the connection", e);
>>>>>>>
logger.warn("Error while closing the connection: {}", e.getMessage());
if (logger.isDebugEnabled()) {
logger.warn("Full stacktrace", e);
}
<<<<<<<
if (!closed) {
documentService.index(
fsSettings.getElasticsearch().getIndex(),
id,
doc,
fsSettings.getElasticsearch().getPipeline());
} else {
logger.warn("trying to add new file while closing crawler. Document [{}]/[{}] has been ignored",
fsSettings.getElasticsearch().getIndex(), id);
}
=======
FSCrawlerLogger.documentDebug(generateIdFromFilename(filename, dirname),
computeVirtualPathName(stats.getRootPath(), fullFilename),
"Indexing content");
esIndex(fsSettings.getElasticsearch().getIndex(),
generateIdFromFilename(filename, dirname),
DocParser.toJson(doc),
fsSettings.getElasticsearch().getPipeline());
>>>>>>>
if (!closed) {
FSCrawlerLogger.documentDebug(id,
computeVirtualPathName(stats.getRootPath(), fullFilename),
"Indexing content");
documentService.index(
fsSettings.getElasticsearch().getIndex(),
id,
doc,
fsSettings.getElasticsearch().getPipeline());
} else {
logger.warn("trying to add new file while closing crawler. Document [{}]/[{}] has been ignored",
fsSettings.getElasticsearch().getIndex(), id);
}
<<<<<<<
// We index the xml content directly (after transformation to json)
if (!closed) {
documentService.indexRawJson(
fsSettings.getElasticsearch().getIndex(),
id,
XmlDocParser.generate(inputStream),
fsSettings.getElasticsearch().getPipeline());
} else {
logger.warn("trying to add new file while closing crawler. Document [{}]/[{}] has been ignored",
fsSettings.getElasticsearch().getIndex(), id);
}
=======
FSCrawlerLogger.documentDebug(generateIdFromFilename(filename, dirname),
computeVirtualPathName(stats.getRootPath(), fullFilename),
"Indexing xml content");
// We index the xml content directly
esIndex(fsSettings.getElasticsearch().getIndex(),
generateIdFromFilename(filename, dirname),
XmlDocParser.generate(inputStream),
fsSettings.getElasticsearch().getPipeline());
>>>>>>>
FSCrawlerLogger.documentDebug(generateIdFromFilename(filename, dirname),
computeVirtualPathName(stats.getRootPath(), fullFilename),
"Indexing xml content");
// We index the xml content directly (after transformation to json)
if (!closed) {
documentService.indexRawJson(
fsSettings.getElasticsearch().getIndex(),
id,
XmlDocParser.generate(inputStream),
fsSettings.getElasticsearch().getPipeline());
} else {
logger.warn("trying to add new file while closing crawler. Document [{}]/[{}] has been ignored",
fsSettings.getElasticsearch().getIndex(), id);
} |
<<<<<<<
this.labels = new HashSet<>();
this.filteredAllTables = sqlgGraph.getSchemaManager().getAllTables();
=======
this.labels = Collections.emptySet();
>>>>>>>
this.labels = Collections.emptySet();
this.filteredAllTables = sqlgGraph.getSchemaManager().getAllTables(); |
<<<<<<<
public <L, R> void bulkAddEdges(String outVertexLabel, String inVertexLabel, String edgeLabel, Pair<String, String> idFields, List<Pair<L, R>> uids) {
=======
public <L, R> void bulkAddEdges(String inVertexLabel, String outVertexLabel, String edgeLabel, Pair<String, String> idFields, Collection<Pair<L, R>> uids) {
>>>>>>>
public <L, R> void bulkAddEdges(String outVertexLabel, String inVertexLabel, String edgeLabel, Pair<String, String> idFields, List<Pair<L, R>> uids) {
public <L, R> void bulkAddEdges(String inVertexLabel, String outVertexLabel, String edgeLabel, Pair<String, String> idFields, Collection<Pair<L, R>> uids) { |
<<<<<<<
@Override
public boolean supportsPartitioning() {
return true;
}
@Override
public List<Map<String, String>> getPartitions(Connection connection) {
List<Map<String, String>> result = new ArrayList<>();
try (Statement statement = connection.createStatement()) {
ResultSet resultSet = statement.executeQuery("with pg_partitioned_table as (select \n" +
" p.partrelid,\n" +
" p.partstrat as partitionType,\n" +
" p.partnatts,\n" +
" string_agg(a.attname, ',' order by a.attnum) \"partitionExpression1\",\n" +
" pg_get_expr(p.partexprs, p.partrelid) \"partitionExpression2\"\n" +
"from \n" +
"(select \n" +
"\tpartrelid,\n" +
" partstrat,\n" +
" partnatts,\n" +
" unnest(partattrs) partattrs,\n" +
" partexprs\n" +
"from \n" +
"\tpg_catalog.pg_partitioned_table\n" +
") p left join\n" +
"\tpg_catalog.pg_attribute a on partrelid = a.attrelid and p.partattrs = a.attnum\n" +
"group by \n" +
"\t1,2,3,5\n" +
")\n" +
"SELECT\n" +
"\tn.nspname as schema,\n" +
"\t(i.inhparent::regclass)::text as parent,\n" +
"\t(cl.oid::regclass)::text as child,\n" +
" p.partitionType,\n" +
" p.\"partitionExpression1\",\n" +
" p.\"partitionExpression2\",\n" +
" pg_get_expr(cl.relpartbound, cl.oid, true) as \"fromToIn\"\n" +
"FROM\n" +
" sqlg_schema.\"V_schema\" s join\n" +
"\tpg_catalog.pg_namespace n on s.name = n.nspname join\n" +
" pg_catalog.pg_class cl on cl.relnamespace = n.oid left join\n" +
" pg_catalog.pg_inherits i on i.inhrelid = cl.oid left join\n" +
" pg_partitioned_table p on p.partrelid = cl.relfilenode\n" +
"WHERE\n" +
"\tcl.relkind <> 'S' AND " +
"(p.\"partitionExpression1\" is not null or p.\"partitionExpression2\" is not null or cl.relpartbound is not null)");
while (resultSet.next()) {
Map<String, String> row = new HashMap<>();
row.put("schema", resultSet.getString("schema"));
row.put("parent", resultSet.getString("parent"));
row.put("child", resultSet.getString("child"));
row.put("partitionType", resultSet.getString("partitionType"));
row.put("partitionExpression1", resultSet.getString("partitionExpression1"));
row.put("partitionExpression2", resultSet.getString("partitionExpression2"));
row.put("fromToIn", resultSet.getString("fromToIn"));
result.add(row);
}
return result;
} catch (SQLException e) {
throw new RuntimeException(e);
}
}
/**
* https://jdbc.postgresql.org/documentation/head/query.html#query-with-cursor
* this is critical to use a cursor, otherwise we load everything into memory
*/
@Override
public Integer getDefaultFetchSize() {
return 1_000;
};
=======
>>>>>>>
@Override
public boolean supportsPartitioning() {
return true;
}
@Override
public List<Map<String, String>> getPartitions(Connection connection) {
List<Map<String, String>> result = new ArrayList<>();
try (Statement statement = connection.createStatement()) {
ResultSet resultSet = statement.executeQuery("with pg_partitioned_table as (select \n" +
" p.partrelid,\n" +
" p.partstrat as partitionType,\n" +
" p.partnatts,\n" +
" string_agg(a.attname, ',' order by a.attnum) \"partitionExpression1\",\n" +
" pg_get_expr(p.partexprs, p.partrelid) \"partitionExpression2\"\n" +
"from \n" +
"(select \n" +
"\tpartrelid,\n" +
" partstrat,\n" +
" partnatts,\n" +
" unnest(partattrs) partattrs,\n" +
" partexprs\n" +
"from \n" +
"\tpg_catalog.pg_partitioned_table\n" +
") p left join\n" +
"\tpg_catalog.pg_attribute a on partrelid = a.attrelid and p.partattrs = a.attnum\n" +
"group by \n" +
"\t1,2,3,5\n" +
")\n" +
"SELECT\n" +
"\tn.nspname as schema,\n" +
"\t(i.inhparent::regclass)::text as parent,\n" +
"\t(cl.oid::regclass)::text as child,\n" +
" p.partitionType,\n" +
" p.\"partitionExpression1\",\n" +
" p.\"partitionExpression2\",\n" +
" pg_get_expr(cl.relpartbound, cl.oid, true) as \"fromToIn\"\n" +
"FROM\n" +
" sqlg_schema.\"V_schema\" s join\n" +
"\tpg_catalog.pg_namespace n on s.name = n.nspname join\n" +
" pg_catalog.pg_class cl on cl.relnamespace = n.oid left join\n" +
" pg_catalog.pg_inherits i on i.inhrelid = cl.oid left join\n" +
" pg_partitioned_table p on p.partrelid = cl.relfilenode\n" +
"WHERE\n" +
"\tcl.relkind <> 'S' AND " +
"(p.\"partitionExpression1\" is not null or p.\"partitionExpression2\" is not null or cl.relpartbound is not null)");
while (resultSet.next()) {
Map<String, String> row = new HashMap<>();
row.put("schema", resultSet.getString("schema"));
row.put("parent", resultSet.getString("parent"));
row.put("child", resultSet.getString("child"));
row.put("partitionType", resultSet.getString("partitionType"));
row.put("partitionExpression1", resultSet.getString("partitionExpression1"));
row.put("partitionExpression2", resultSet.getString("partitionExpression2"));
row.put("fromToIn", resultSet.getString("fromToIn"));
result.add(row);
}
return result;
} catch (SQLException e) {
throw new RuntimeException(e);
}
} |
<<<<<<<
JsonTest.class,
TestBatchCompleteVertex.class,
TestBatchCompleteEdge.class
=======
JsonTest.class,
TestLockedByCurrentThreadPerformance.class,
TestSchemaManagerGetTablesFor.class
>>>>>>>
TestBatchCompleteVertex.class,
TestBatchCompleteEdge.class
JsonTest.class,
TestLockedByCurrentThreadPerformance.class,
TestSchemaManagerGetTablesFor.class |
<<<<<<<
import org.postgis.Geometry;
import org.postgis.PGgeometry;
import org.postgis.Point;
import org.postgis.Polygon;
=======
import org.postgresql.PGConnection;
>>>>>>>
import org.postgis.Geometry;
import org.postgis.PGgeometry;
import org.postgis.Point;
import org.postgis.Polygon;
import org.postgresql.PGConnection;
<<<<<<<
import java.lang.reflect.Method;
=======
import java.io.OutputStream;
import java.lang.reflect.*;
>>>>>>>
import java.lang.reflect.Method;
import java.io.OutputStream;
import java.lang.reflect.*;
<<<<<<<
@Override
public boolean isPostgresql() {
return true;
}
@Override
public void registerGisDataTypes(Connection connection) {
try {
((Jdbc4Connection)((com.mchange.v2.c3p0.impl.NewProxyConnection) connection).unwrap(Jdbc4Connection.class)).addDataType("geometry", "org.postgis.PGgeometry");
} catch (SQLException e) {
throw new RuntimeException(e);
}
}
@Override
public <T> T getGis(SqlgGraph sqlgGraph) {
Gis gis = Gis.GIS;
gis.setSqlgGraph(sqlgGraph);
return (T)gis;
}
=======
@Override
public OutputStream streamSql(SqlgGraph sqlgGraph, String sql) {
C3P0ProxyConnection conn = (C3P0ProxyConnection) sqlgGraph.tx().getConnection();
PGConnection pgConnection;
try {
pgConnection = conn.unwrap(PGConnection.class);
return new PGCopyOutputStream(pgConnection, sql);
} catch (SQLException e) {
throw new RuntimeException(e);
}
}
>>>>>>>
@Override
public OutputStream streamSql(SqlgGraph sqlgGraph, String sql) {
C3P0ProxyConnection conn = (C3P0ProxyConnection) sqlgGraph.tx().getConnection();
PGConnection pgConnection;
try {
pgConnection = conn.unwrap(PGConnection.class);
return new PGCopyOutputStream(pgConnection, sql);
} catch (SQLException e) {
throw new RuntimeException(e);
}
}
@Override
public boolean isPostgresql() {
return true;
}
@Override
public void registerGisDataTypes(Connection connection) {
try {
((Jdbc4Connection)((com.mchange.v2.c3p0.impl.NewProxyConnection) connection).unwrap(Jdbc4Connection.class)).addDataType("geometry", "org.postgis.PGgeometry");
} catch (SQLException e) {
throw new RuntimeException(e);
}
}
@Override
public <T> T getGis(SqlgGraph sqlgGraph) {
Gis gis = Gis.GIS;
gis.setSqlgGraph(sqlgGraph);
return (T)gis;
} |
<<<<<<<
public <L, R> void bulkAddEdges(SqlgGraph sqlgGraph, SchemaTable out, SchemaTable in, String edgeLabel, Pair<String, String> idFields, List<Pair<L, R>> uids) {
=======
public <L, R> void bulkAddEdges(SqlgGraph sqlgGraph, SchemaTable in, SchemaTable out, String edgeLabel, Pair<String, String> idFields, Collection<Pair<L, R>> uids) {
>>>>>>>
public <L, R> void bulkAddEdges(SqlgGraph sqlgGraph, SchemaTable out, SchemaTable in, String edgeLabel, Pair<String, String> idFields, List<Pair<L, R>> uids) {
public <L, R> void bulkAddEdges(SqlgGraph sqlgGraph, SchemaTable in, SchemaTable out, String edgeLabel, Pair<String, String> idFields, Collection<Pair<L, R>> uids) { |
<<<<<<<
for (Message<?> msg : messages) {
=======
org.apache.rocketmq.common.message.Message rocketMsg;
for (Message msg:messages) {
>>>>>>>
for (Message msg : messages) { |
<<<<<<<
public void testDefaultMQProducerWithRelaxPropertyName() {
runner.withPropertyValues("spring.rocketmq.name-server=127.0.0.1:9876",
=======
public void testDefaultMQProducer() {
runner.withPropertyValues("spring.rocketmq.name-server=127.0.0.1:9876",
>>>>>>>
public void testDefaultMQProducerWithRelaxPropertyName() {
runner.withPropertyValues("spring.rocketmq.nameServer=127.0.0.1:9876", |
<<<<<<<
import static com.greghaskins.spectrum.Spectrum.let;
import static com.greghaskins.spectrum.Spectrum.value;
import static com.greghaskins.spectrum.Spectrum.xdescribe;
=======
>>>>>>>
import static com.greghaskins.spectrum.Spectrum.let;
import static com.greghaskins.spectrum.Spectrum.xdescribe;
<<<<<<<
import static org.hamcrest.Matchers.hasItem;
=======
import static org.hamcrest.Matchers.empty;
>>>>>>>
import static org.hamcrest.Matchers.empty;
import static org.hamcrest.Matchers.hasItem;
<<<<<<<
import com.greghaskins.spectrum.Spectrum.Value;
import com.greghaskins.spectrum.SpectrumHelper;
=======
>>>>>>>
import com.greghaskins.spectrum.Spectrum.ThrowingSupplier;
import com.greghaskins.spectrum.SpectrumHelper; |
<<<<<<<
import com.greghaskins.spectrum.Spectrum.Value;
import com.greghaskins.spectrum.SpectrumHelper;
=======
>>>>>>>
import com.greghaskins.spectrum.SpectrumHelper;
<<<<<<<
final Value<Result> result = value();
beforeEach(() -> {
result.value = SpectrumHelper.run(getIgnoredSpecsExample());
});
=======
final Supplier<Result> result = let(() -> SpectrumRunner.run(getIgnoredSpecsExample()));
>>>>>>>
final Supplier<Result> result = let(() -> SpectrumHelper.run(getIgnoredSpecsExample())); |
<<<<<<<
import com.greghaskins.spectrum.Spectrum.Value;
import com.greghaskins.spectrum.SpectrumHelper;
=======
>>>>>>>
import com.greghaskins.spectrum.SpectrumHelper;
<<<<<<<
final Value<Result> result = value();
beforeEach(() -> {
result.value = SpectrumHelper.run(getFocusedSpecsExample());
});
=======
final Supplier<Result> result = let(() -> SpectrumRunner.run(getFocusedSpecsExample()));
>>>>>>>
final Supplier<Result> result = let(() -> SpectrumHelper.run(getFocusedSpecsExample())); |
<<<<<<<
if (Reddit.cache) {
Cache.writeSubreddit(things, subredditPaginators[0]);
}
} catch(Exception e){
e.printStackTrace();
=======
if (SettingValues.cache) {
Cache.writeSubreddit(things, subredditPaginators[0]);
>>>>>>>
if (SettingValues.cache) {
Cache.writeSubreddit(things, subredditPaginators[0]);
}
} catch(Exception e){
e.printStackTrace(); |
<<<<<<<
infoBar = InfoBar.valueOf(settings.getString("infoBarType", "BIG_PICTURE"));
=======
infoBar = settings.getBoolean("infoBar", true);
defaultSorting = Sorting.valueOf(settings.getString("defaultSorting", "HOT"));
timePeriod = TimePeriod.valueOf(settings.getString("timePeriod", "DAY"));
defaultCommentSorting = CommentSort.valueOf(settings.getString("defaultCommentSorting", "TOP"));
>>>>>>>
infoBar = InfoBar.valueOf(settings.getString("infoBarType", "BIG_PICTURE"));
defaultSorting = Sorting.valueOf(settings.getString("defaultSorting", "HOT"));
timePeriod = TimePeriod.valueOf(settings.getString("timePeriod", "DAY"));
defaultCommentSorting = CommentSort.valueOf(settings.getString("defaultCommentSorting", "TOP")); |
<<<<<<<
=======
public void updateMultiNameToSubs(Map<String, String> subs) {
multiNameToSubsMap = subs;
}
>>>>>>>
public void updateMultiNameToSubs(Map<String, String> subs) {
multiNameToSubsMap = subs;
}
<<<<<<<
if (SettingValues.subredditSearchMethod == R.integer.SUBREDDIT_SEARCH_METHOD_DRAWER) {
e = ((EditText) headerMain.findViewById(R.id.sort));
e.setVisibility(View.VISIBLE);
headerMain.findViewById(R.id.close_search_drawer).setOnClickListener(new View.OnClickListener() {
@Override
public void onClick(View v) {
e.setText("");
}
});
e.setOnFocusChangeListener(new View.OnFocusChangeListener() {
@Override
public void onFocusChange(View v, boolean hasFocus) {
drawerSubList.smoothScrollToPositionFromTop(1, e.getHeight());
}
});
e.setOnEditorActionListener(new TextView.OnEditorActionListener() {
@Override
public boolean onEditorAction(TextView arg0, int arg1, KeyEvent arg2) {
if (arg1 == EditorInfo.IME_ACTION_SEARCH) {
//If it the input text doesn't match a subreddit from the list exactly, openInSubView is true
if (sideArrayAdapter.fitems == null || sideArrayAdapter.openInSubView || !usedArray.contains(e.getText().toString().toLowerCase())) {
Intent inte = new Intent(MainActivity.this, SubredditView.class);
inte.putExtra(SubredditView.EXTRA_SUBREDDIT, e.getText().toString());
MainActivity.this.startActivity(inte);
} else {
if(commentPager && adapter instanceof OverviewPagerAdapterComment){
openingComments = null;
toOpenComments = -1;
((MainActivity.OverviewPagerAdapterComment)adapter).size = (usedArray.size() + 1);
adapter.notifyDataSetChanged();
if (usedArray.contains(e.getText().toString().toLowerCase())) {
doPageSelectedComments(usedArray.indexOf(e.getText().toString().toLowerCase()));
} else {
doPageSelectedComments(usedArray.indexOf(sideArrayAdapter.fitems.get(0)));
}
}
=======
e.setOnFocusChangeListener(new View.OnFocusChangeListener() {
@Override
public void onFocusChange(View v, boolean hasFocus) {
drawerSubList.smoothScrollToPositionFromTop(1, e.getHeight(), 100);
}
});
e.setOnEditorActionListener(new TextView.OnEditorActionListener() {
@Override
public boolean onEditorAction(TextView arg0, int arg1, KeyEvent arg2) {
if (arg1 == EditorInfo.IME_ACTION_SEARCH) {
//If it the input text doesn't match a subreddit from the list exactly, openInSubView is true
if (sideArrayAdapter.fitems == null || sideArrayAdapter.openInSubView || !usedArray.contains(e.getText().toString().toLowerCase())) {
Intent inte = new Intent(MainActivity.this, SubredditView.class);
inte.putExtra(SubredditView.EXTRA_SUBREDDIT, e.getText().toString());
MainActivity.this.startActivity(inte);
} else {
if (commentPager && adapter instanceof OverviewPagerAdapterComment) {
openingComments = null;
toOpenComments = -1;
((MainActivity.OverviewPagerAdapterComment) adapter).size = (usedArray.size() + 1);
adapter.notifyDataSetChanged();
>>>>>>>
if (SettingValues.subredditSearchMethod == R.integer.SUBREDDIT_SEARCH_METHOD_DRAWER) {
e = ((EditText) headerMain.findViewById(R.id.sort));
e.setVisibility(View.VISIBLE);
headerMain.findViewById(R.id.close_search_drawer).setOnClickListener(new View.OnClickListener() {
@Override
public void onClick(View v) {
e.setText("");
}
});
e.setOnFocusChangeListener(new View.OnFocusChangeListener() {
@Override
public void onFocusChange(View v, boolean hasFocus) {
drawerSubList.smoothScrollToPositionFromTop(1, e.getHeight(), 100);
}
});
e.setOnEditorActionListener(new TextView.OnEditorActionListener() {
@Override
public boolean onEditorAction(TextView arg0, int arg1, KeyEvent arg2) {
if (arg1 == EditorInfo.IME_ACTION_SEARCH) {
//If it the input text doesn't match a subreddit from the list exactly, openInSubView is true
if (sideArrayAdapter.fitems == null || sideArrayAdapter.openInSubView || !usedArray.contains(e.getText().toString().toLowerCase())) {
Intent inte = new Intent(MainActivity.this, SubredditView.class);
inte.putExtra(SubredditView.EXTRA_SUBREDDIT, e.getText().toString());
MainActivity.this.startActivity(inte);
} else {
if (commentPager && adapter instanceof OverviewPagerAdapterComment) {
openingComments = null;
toOpenComments = -1;
((MainActivity.OverviewPagerAdapterComment) adapter).size = (usedArray.size() + 1);
adapter.notifyDataSetChanged();
if (usedArray.contains(e.getText().toString().toLowerCase())) {
doPageSelectedComments(usedArray.indexOf(e.getText().toString().toLowerCase()));
} else {
doPageSelectedComments(usedArray.indexOf(sideArrayAdapter.fitems.get(0)));
}
} |
<<<<<<<
=======
Log.v(LogUtil.getTag(), "WILL SWIPE FROM ANYWHERE");
>>>>>>>
Log.v(LogUtil.getTag(), "WILL SWIPE FROM ANYWHERE");
<<<<<<<
=======
Log.v(LogUtil.getTag(), "EDGE SIZE IS " + metrics.widthPixels);
>>>>>>>
Log.v(LogUtil.getTag(), "EDGE SIZE IS " + metrics.widthPixels); |
<<<<<<<
=======
postFab = (FloatingActionButton) findViewById(R.id.post_floating_action_button);
if (Reddit.fab) {
postFab.setOnClickListener(new View.OnClickListener() {
@Override
public void onClick(View v) {
startActivity(new Intent(getApplicationContext(), Submit.class));
}
});
} else {
postFab.hide();
postFab.setVisibility(View.INVISIBLE);
}
>>>>>>> |
<<<<<<<
=======
import me.ccrama.redditslide.ContentType;
import me.ccrama.redditslide.HasSeen;
import me.ccrama.redditslide.PostLoaderManager;
>>>>>>>
import me.ccrama.redditslide.PostLoaderManager; |
<<<<<<<
=======
// Set if Gitty can use your Auth token for users without a GitHub account (default: true)
// If false, Gitty will redirect non registered users to github.com/join
enableGuestGitHubLogin();
>>>>>>> |
<<<<<<<
SpannableStringBuilder builder = new SpannableStringBuilder();
int start;
int codeStartInSequence;
int end;
int codeStartInBuilder;
int codeEndInBuilder;
String code;
while (sequenceString.contains(startSeq)) {
start = 0;
codeStartInSequence = sequenceString.indexOf(startSeq) + startSeq.length();
end = sequenceString.indexOf(endSeq);
code = sequenceString.substring(start, end).replace(startSeq, "");
builder.append(code);
=======
>>>>>>> |
<<<<<<<
=======
import com.afollestad.materialdialogs.AlertDialogWrapper;
import com.google.gson.JsonObject;
import com.koushikdutta.async.future.FutureCallback;
import com.koushikdutta.ion.Ion;
import java.io.BufferedInputStream;
import java.io.File;
import java.io.FileOutputStream;
import java.io.InputStream;
import java.net.URL;
import java.net.URLConnection;
import me.ccrama.redditslide.DataShare;
import me.ccrama.redditslide.ImageLoaderUtils;
>>>>>>>
<<<<<<<
import me.ccrama.redditslide.util.GifUtils;
=======
import me.ccrama.redditslide.util.LogUtil;
>>>>>>>
import me.ccrama.redditslide.util.GifUtils;
import me.ccrama.redditslide.util.LogUtil; |
<<<<<<<
private void doPage(int i, View container){
((TextView) container.findViewById(R.id.submission_title)).setText(titles[i]);
=======
public void doPage(int i, View container){
((TextView) container.findViewById(R.id.submission_title)).setText(titles(getContext())[i]);
>>>>>>>
private void doPage(int i, View container){
((TextView) container.findViewById(R.id.submission_title)).setText(titles(getContext())[i]);
<<<<<<<
private static final String[] titles = new String[]{
"Swipe to switch subreddits",
"Tap a submission to open in in full view",
"Slide up to see comments in full view",
"Tap a name to view user",
"Hide comments with a single tap",
"You can swipe to the next submission in full view",
"Open content from full view",
"Open content from list view"
};
private static final int[] dataBits = new int[]{
=======
public static String[] titles(Context context) {
return new String[]{
context.getString(R.string.tutorial_swipe_subreddits),
context.getString(R.string.tutorial_tap_full_view),
context.getString(R.string.tutorial_slide_comments),
context.getString(R.string.tutorial_tap_name),
context.getString(R.string.tutorial_tap_hide),
context.getString(R.string.tutorial_swipe_next),
context.getString(R.string.tutorial_open_full),
context.getString(R.string.tutorial_open_list)
};
}
public static int[] dataBits = new int[]{
>>>>>>>
public static String[] titles(Context context) {
return new String[]{
context.getString(R.string.tutorial_swipe_subreddits),
context.getString(R.string.tutorial_tap_full_view),
context.getString(R.string.tutorial_slide_comments),
context.getString(R.string.tutorial_tap_name),
context.getString(R.string.tutorial_tap_hide),
context.getString(R.string.tutorial_swipe_next),
context.getString(R.string.tutorial_open_full),
context.getString(R.string.tutorial_open_list)
};
}
private static final int[] dataBits = new int[]{ |
<<<<<<<
=======
import android.content.DialogInterface;
>>>>>>>
<<<<<<<
=======
import android.media.MediaPlayer;
import android.os.AsyncTask;
>>>>>>>
<<<<<<<
=======
import android.util.Log;
>>>>>>>
<<<<<<<
=======
public static String getSmallerGfy(String gfyUrl) {
gfyUrl = gfyUrl.replaceAll("fat|zippy|giant", "thumbs")
.replaceAll("\\.mp4|\\.webm", "-mobile.mp4");
return gfyUrl;
}
>>>>>>> |
<<<<<<<
import org.saiku.olap.query2.ThinQuery;
import org.saiku.service.util.ISaikuQuery;
=======
import org.saiku.olap.dto.resultset.CellDataSet;
import org.saiku.web.rest.util.RestUtil;
>>>>>>>
import org.saiku.olap.dto.resultset.CellDataSet;
import org.saiku.olap.query2.ThinQuery;
import org.saiku.service.util.ISaikuQuery;
import org.saiku.web.rest.util.RestUtil;
<<<<<<<
private ISaikuQuery query;
=======
private int topOffset;
private int leftOffset;
public QueryResult(List<Cell[]> cellset, CellDataSet cellDataSet) {
this(cellset, cellDataSet.getRuntime(), cellDataSet.getWidth(), cellDataSet.getHeight(), cellDataSet.getLeftOffset(), cellDataSet.getTopOffset(), RestUtil.convertTotals(cellDataSet.getRowTotalsLists()), RestUtil.convertTotals(cellDataSet.getColTotalsLists()));
}
public QueryResult(List<Cell[]> cellset, int runtime, int width, int height, int leftOffset, int topOffset, Total[][] rowTotalsLists, Total[][] colTotalsLists) {
this(cellset, runtime, width, height);
this.rowTotalsLists = rowTotalsLists;
this.colTotalsLists = colTotalsLists;
this.topOffset = topOffset;
this.leftOffset = leftOffset;
}
>>>>>>>
private ISaikuQuery query;
private int topOffset;
private int leftOffset;
public QueryResult(List<Cell[]> cellset, CellDataSet cellDataSet) {
this(cellset, cellDataSet.getRuntime(), cellDataSet.getWidth(), cellDataSet.getHeight(), cellDataSet.getLeftOffset(), cellDataSet.getTopOffset(), RestUtil.convertTotals(cellDataSet.getRowTotalsLists()), RestUtil.convertTotals(cellDataSet.getColTotalsLists()));
}
public QueryResult(List<Cell[]> cellset, int runtime, int width, int height, int leftOffset, int topOffset, Total[][] rowTotalsLists, Total[][] colTotalsLists) {
this(cellset, runtime, width, height);
this.rowTotalsLists = rowTotalsLists;
this.colTotalsLists = colTotalsLists;
this.topOffset = topOffset;
this.leftOffset = leftOffset;
} |
<<<<<<<
private static byte[] getExcel(CellDataSet table, List<ThinHierarchy> filters) {
=======
private static byte[] getExcel(CellDataSet table, List<SaikuDimensionSelection> filters, ExcelBuilderOptions options) {
>>>>>>>
private static byte[] getExcel(CellDataSet table, List<ThinHierarchy> filters, ExcelBuilderOptions options) { |
<<<<<<<
import org.saiku.olap.dto.SimpleCubeElement;
import org.saiku.olap.dto.filter.SaikuFilter;
import org.saiku.service.ISessionService;
import org.saiku.service.olap.OlapQueryService;
import org.saiku.service.util.exception.SaikuServiceException;
import com.fasterxml.jackson.annotation.JsonAutoDetect;
import com.fasterxml.jackson.databind.ObjectMapper;
import com.fasterxml.jackson.databind.type.MapType;
import com.fasterxml.jackson.databind.type.TypeFactory;
import org.apache.commons.collections.MapUtils;
import org.apache.commons.lang.StringUtils;
import org.apache.commons.lang.exception.ExceptionUtils;
import org.apache.commons.vfs.*;
=======
import org.saiku.olap.dto.SimpleCubeElement;
import org.saiku.olap.dto.filter.SaikuFilter;
import org.saiku.service.ISessionService;
import org.saiku.service.olap.OlapQueryService;
import org.saiku.service.util.exception.SaikuServiceException;
import com.qmino.miredot.annotations.ReturnType;
import org.apache.commons.collections.MapUtils;
import org.apache.commons.lang.StringUtils;
import org.apache.commons.lang.exception.ExceptionUtils;
import org.apache.commons.vfs.*;
import org.codehaus.jackson.annotate.JsonAutoDetect.Visibility;
import org.codehaus.jackson.map.ObjectMapper;
import org.codehaus.jackson.map.type.TypeFactory;
>>>>>>>
import org.saiku.olap.dto.SimpleCubeElement;
import org.saiku.olap.dto.filter.SaikuFilter;
import org.saiku.service.ISessionService;
import org.saiku.service.olap.OlapQueryService;
import org.saiku.service.util.exception.SaikuServiceException;
import com.fasterxml.jackson.annotation.JsonAutoDetect;
import com.fasterxml.jackson.databind.ObjectMapper;
import com.fasterxml.jackson.databind.type.MapType;
import com.fasterxml.jackson.databind.type.TypeFactory;
import com.qmino.miredot.annotations.ReturnType;
import org.apache.commons.collections.MapUtils;
import org.apache.commons.lang.StringUtils;
import org.apache.commons.lang.exception.ExceptionUtils;
import org.apache.commons.vfs.*; |
<<<<<<<
protected final List<ResourceExtension> resourceExtensions = new ArrayList<>();
=======
protected SslContextFactory sslContextFactory;
>>>>>>>
protected final List<ResourceExtension> resourceExtensions = new ArrayList<>();
protected SslContextFactory sslContextFactory;
<<<<<<<
* add any servlet filters that should be called before resource handling
*/
protected void configurePreResourceHandling(ServletContextHandler context) {}
/**
=======
* expose SslContextFactory
*/
protected SslContextFactory getSslContextFactory() {
return this.sslContextFactory;
}
/**
>>>>>>>
* add any servlet filters that should be called before resource handling
*/
protected void configurePreResourceHandling(ServletContextHandler context) {}
/**
* expose SslContextFactory
*/
protected SslContextFactory getSslContextFactory() {
return this.sslContextFactory;
}
/**
<<<<<<<
SslContextFactory sslContextFactory = new SslContextFactory();
if (!config.getString(RestConfig.SSL_KEYSTORE_LOCATION_CONFIG).isEmpty()) {
sslContextFactory.setKeyStorePath(
config.getString(RestConfig.SSL_KEYSTORE_LOCATION_CONFIG)
);
sslContextFactory.setKeyStorePassword(
config.getPassword(RestConfig.SSL_KEYSTORE_PASSWORD_CONFIG).value()
);
sslContextFactory.setKeyManagerPassword(
config.getPassword(RestConfig.SSL_KEY_PASSWORD_CONFIG).value()
);
sslContextFactory.setKeyStoreType(
config.getString(RestConfig.SSL_KEYSTORE_TYPE_CONFIG)
);
if (!config.getString(RestConfig.SSL_KEYMANAGER_ALGORITHM_CONFIG).isEmpty()) {
sslContextFactory.setKeyManagerFactoryAlgorithm(
config.getString(RestConfig.SSL_KEYMANAGER_ALGORITHM_CONFIG));
}
}
sslContextFactory.setNeedClientAuth(config.getBoolean(RestConfig.SSL_CLIENT_AUTH_CONFIG));
List<String> enabledProtocols = config.getList(RestConfig.SSL_ENABLED_PROTOCOLS_CONFIG);
if (!enabledProtocols.isEmpty()) {
sslContextFactory.setIncludeProtocols(enabledProtocols.toArray(new String[0]));
}
List<String> cipherSuites = config.getList(RestConfig.SSL_CIPHER_SUITES_CONFIG);
if (!cipherSuites.isEmpty()) {
sslContextFactory.setIncludeCipherSuites(cipherSuites.toArray(new String[0]));
}
if (!config.getString(RestConfig.SSL_ENDPOINT_IDENTIFICATION_ALGORITHM_CONFIG).isEmpty()) {
sslContextFactory.setEndpointIdentificationAlgorithm(
config.getString(RestConfig.SSL_ENDPOINT_IDENTIFICATION_ALGORITHM_CONFIG));
}
if (!config.getString(RestConfig.SSL_TRUSTSTORE_LOCATION_CONFIG).isEmpty()) {
sslContextFactory.setTrustStorePath(
config.getString(RestConfig.SSL_TRUSTSTORE_LOCATION_CONFIG)
);
sslContextFactory.setTrustStorePassword(
config.getPassword(RestConfig.SSL_TRUSTSTORE_PASSWORD_CONFIG).value()
);
sslContextFactory.setTrustStoreType(
config.getString(RestConfig.SSL_TRUSTSTORE_TYPE_CONFIG)
);
if (!config.getString(RestConfig.SSL_TRUSTMANAGER_ALGORITHM_CONFIG).isEmpty()) {
sslContextFactory.setTrustManagerFactoryAlgorithm(
config.getString(RestConfig.SSL_TRUSTMANAGER_ALGORITHM_CONFIG)
);
}
}
sslContextFactory.setProtocol(config.getString(RestConfig.SSL_PROTOCOL_CONFIG));
if (!config.getString(RestConfig.SSL_PROVIDER_CONFIG).isEmpty()) {
sslContextFactory.setProtocol(config.getString(RestConfig.SSL_PROVIDER_CONFIG));
}
sslContextFactory.setRenegotiationAllowed(false);
=======
>>>>>>>
<<<<<<<
private boolean isCorsEnabled() {
return AuthUtil.isCorsEnabled(config);
}
@SuppressWarnings("unchecked")
private void configureResourceExtensions(final ResourceConfig resourceConfig) {
resourceExtensions.addAll(getConfiguration().getConfiguredInstances(
RestConfig.RESOURCE_EXTENSION_CLASSES_CONFIG, ResourceExtension.class));
resourceExtensions.forEach(ext -> {
try {
ext.register(resourceConfig, this);
} catch (Exception e) {
throw new RuntimeException("Exception throw by resource extension. ext:" + ext, e);
}
});
}
@SuppressWarnings("unchecked")
private void applyCustomConfiguration(
ServletContextHandler context,
String initializerConfigName) {
getConfiguration()
.getConfiguredInstances(initializerConfigName, Consumer.class)
.forEach(initializer -> {
try {
initializer.accept(context);
} catch (final Exception e) {
throw new RuntimeException("Exception from custom initializer. "
+ "config:" + initializerConfigName + ", initializer" + initializer, e);
}
});
}
protected void configureSecurityHandler(ServletContextHandler context) {
String authMethod = config.getString(RestConfig.AUTHENTICATION_METHOD_CONFIG);
if (enableBasicAuth(authMethod)) {
context.setSecurityHandler(createBasicSecurityHandler());
}
}
=======
private SslContextFactory createSslContextFactory() {
SslContextFactory sslContextFactory = new SslContextFactory();
if (!config.getString(RestConfig.SSL_KEYSTORE_LOCATION_CONFIG).isEmpty()) {
sslContextFactory.setKeyStorePath(
config.getString(RestConfig.SSL_KEYSTORE_LOCATION_CONFIG)
);
sslContextFactory.setKeyStorePassword(
config.getPassword(RestConfig.SSL_KEYSTORE_PASSWORD_CONFIG).value()
);
sslContextFactory.setKeyManagerPassword(
config.getPassword(RestConfig.SSL_KEY_PASSWORD_CONFIG).value()
);
sslContextFactory.setKeyStoreType(
config.getString(RestConfig.SSL_KEYSTORE_TYPE_CONFIG)
);
if (!config.getString(RestConfig.SSL_KEYMANAGER_ALGORITHM_CONFIG).isEmpty()) {
sslContextFactory.setKeyManagerFactoryAlgorithm(
config.getString(RestConfig.SSL_KEYMANAGER_ALGORITHM_CONFIG));
}
}
sslContextFactory.setNeedClientAuth(config.getBoolean(RestConfig.SSL_CLIENT_AUTH_CONFIG));
List<String> enabledProtocols = config.getList(RestConfig.SSL_ENABLED_PROTOCOLS_CONFIG);
if (!enabledProtocols.isEmpty()) {
sslContextFactory.setIncludeProtocols(enabledProtocols.toArray(new String[0]));
}
List<String> cipherSuites = config.getList(RestConfig.SSL_CIPHER_SUITES_CONFIG);
if (!cipherSuites.isEmpty()) {
sslContextFactory.setIncludeCipherSuites(cipherSuites.toArray(new String[0]));
}
if (!config.getString(RestConfig.SSL_ENDPOINT_IDENTIFICATION_ALGORITHM_CONFIG).isEmpty()) {
sslContextFactory.setEndpointIdentificationAlgorithm(
config.getString(RestConfig.SSL_ENDPOINT_IDENTIFICATION_ALGORITHM_CONFIG));
}
if (!config.getString(RestConfig.SSL_TRUSTSTORE_LOCATION_CONFIG).isEmpty()) {
sslContextFactory.setTrustStorePath(
config.getString(RestConfig.SSL_TRUSTSTORE_LOCATION_CONFIG)
);
sslContextFactory.setTrustStorePassword(
config.getPassword(RestConfig.SSL_TRUSTSTORE_PASSWORD_CONFIG).value()
);
sslContextFactory.setTrustStoreType(
config.getString(RestConfig.SSL_TRUSTSTORE_TYPE_CONFIG)
);
if (!config.getString(RestConfig.SSL_TRUSTMANAGER_ALGORITHM_CONFIG).isEmpty()) {
sslContextFactory.setTrustManagerFactoryAlgorithm(
config.getString(RestConfig.SSL_TRUSTMANAGER_ALGORITHM_CONFIG)
);
}
}
sslContextFactory.setProtocol(config.getString(RestConfig.SSL_PROTOCOL_CONFIG));
if (!config.getString(RestConfig.SSL_PROVIDER_CONFIG).isEmpty()) {
sslContextFactory.setProtocol(config.getString(RestConfig.SSL_PROVIDER_CONFIG));
}
return sslContextFactory;
}
>>>>>>>
private boolean isCorsEnabled() {
return AuthUtil.isCorsEnabled(config);
}
@SuppressWarnings("unchecked")
private void configureResourceExtensions(final ResourceConfig resourceConfig) {
resourceExtensions.addAll(getConfiguration().getConfiguredInstances(
RestConfig.RESOURCE_EXTENSION_CLASSES_CONFIG, ResourceExtension.class));
resourceExtensions.forEach(ext -> {
try {
ext.register(resourceConfig, this);
} catch (Exception e) {
throw new RuntimeException("Exception throw by resource extension. ext:" + ext, e);
}
});
}
@SuppressWarnings("unchecked")
private void applyCustomConfiguration(
ServletContextHandler context,
String initializerConfigName) {
getConfiguration()
.getConfiguredInstances(initializerConfigName, Consumer.class)
.forEach(initializer -> {
try {
initializer.accept(context);
} catch (final Exception e) {
throw new RuntimeException("Exception from custom initializer. "
+ "config:" + initializerConfigName + ", initializer" + initializer, e);
}
});
}
protected void configureSecurityHandler(ServletContextHandler context) {
String authMethod = config.getString(RestConfig.AUTHENTICATION_METHOD_CONFIG);
if (enableBasicAuth(authMethod)) {
context.setSecurityHandler(createBasicSecurityHandler());
}
}
private SslContextFactory createSslContextFactory() {
SslContextFactory sslContextFactory = new SslContextFactory();
if (!config.getString(RestConfig.SSL_KEYSTORE_LOCATION_CONFIG).isEmpty()) {
sslContextFactory.setKeyStorePath(
config.getString(RestConfig.SSL_KEYSTORE_LOCATION_CONFIG)
);
sslContextFactory.setKeyStorePassword(
config.getPassword(RestConfig.SSL_KEYSTORE_PASSWORD_CONFIG).value()
);
sslContextFactory.setKeyManagerPassword(
config.getPassword(RestConfig.SSL_KEY_PASSWORD_CONFIG).value()
);
sslContextFactory.setKeyStoreType(
config.getString(RestConfig.SSL_KEYSTORE_TYPE_CONFIG)
);
if (!config.getString(RestConfig.SSL_KEYMANAGER_ALGORITHM_CONFIG).isEmpty()) {
sslContextFactory.setKeyManagerFactoryAlgorithm(
config.getString(RestConfig.SSL_KEYMANAGER_ALGORITHM_CONFIG));
}
}
sslContextFactory.setNeedClientAuth(config.getBoolean(RestConfig.SSL_CLIENT_AUTH_CONFIG));
List<String> enabledProtocols = config.getList(RestConfig.SSL_ENABLED_PROTOCOLS_CONFIG);
if (!enabledProtocols.isEmpty()) {
sslContextFactory.setIncludeProtocols(enabledProtocols.toArray(new String[0]));
}
List<String> cipherSuites = config.getList(RestConfig.SSL_CIPHER_SUITES_CONFIG);
if (!cipherSuites.isEmpty()) {
sslContextFactory.setIncludeCipherSuites(cipherSuites.toArray(new String[0]));
}
if (!config.getString(RestConfig.SSL_ENDPOINT_IDENTIFICATION_ALGORITHM_CONFIG).isEmpty()) {
sslContextFactory.setEndpointIdentificationAlgorithm(
config.getString(RestConfig.SSL_ENDPOINT_IDENTIFICATION_ALGORITHM_CONFIG));
}
if (!config.getString(RestConfig.SSL_TRUSTSTORE_LOCATION_CONFIG).isEmpty()) {
sslContextFactory.setTrustStorePath(
config.getString(RestConfig.SSL_TRUSTSTORE_LOCATION_CONFIG)
);
sslContextFactory.setTrustStorePassword(
config.getPassword(RestConfig.SSL_TRUSTSTORE_PASSWORD_CONFIG).value()
);
sslContextFactory.setTrustStoreType(
config.getString(RestConfig.SSL_TRUSTSTORE_TYPE_CONFIG)
);
if (!config.getString(RestConfig.SSL_TRUSTMANAGER_ALGORITHM_CONFIG).isEmpty()) {
sslContextFactory.setTrustManagerFactoryAlgorithm(
config.getString(RestConfig.SSL_TRUSTMANAGER_ALGORITHM_CONFIG)
);
}
}
sslContextFactory.setProtocol(config.getString(RestConfig.SSL_PROTOCOL_CONFIG));
if (!config.getString(RestConfig.SSL_PROVIDER_CONFIG).isEmpty()) {
sslContextFactory.setProtocol(config.getString(RestConfig.SSL_PROVIDER_CONFIG));
}
sslContextFactory.setRenegotiationAllowed(false);
return sslContextFactory;
} |
<<<<<<<
if (l >= Byte.MIN_VALUE && l <= Byte.MAX_VALUE) {
super.int8((byte) l);
return;
}
if (l >= Short.MIN_VALUE && l <= Short.MAX_VALUE) {
super.int16((short) l);
return;
}
if (l >= Integer.MIN_VALUE && l <= Integer.MAX_VALUE) {
super.int32((int) l);
return;
}
if ((long) (float) l == l) {
super.float32(l);
return;
}
super.int64(l);
}
void writeNumber(double l) {
boolean canOnlyBeRepresentedAsFloatingPoint = ((long) l) != l;
if (l >= 0 && l <= 127 && !canOnlyBeRepresentedAsFloatingPoint) {
// used when the value is written directly into the code byte
bytes.writeUnsignedByte((int) l);
return;
}
if (l >= 0) {
if (l <= (1 << 8) - 1 && !canOnlyBeRepresentedAsFloatingPoint) {
super.uint8checked((short) l);
return;
}
if (l <= (1 << 16) - 1 && !canOnlyBeRepresentedAsFloatingPoint) {
super.uint16checked((int) l);
return;
}
if (((double) (float) l) == l) {
super.float32((float) l);
return;
}
if (l <= (1L << 32L) - 1 && !canOnlyBeRepresentedAsFloatingPoint) {
super.uint32checked((int) l);
return;
}
super.float64(l);
return;
}
if (l >= Byte.MIN_VALUE && l <= Byte.MAX_VALUE && !canOnlyBeRepresentedAsFloatingPoint) {
super.int8((byte) l);
return;
}
if (l >= Short.MIN_VALUE && l <= Short.MAX_VALUE && !canOnlyBeRepresentedAsFloatingPoint) {
super.int16((short) l);
return;
}
if (((double) (float) l) == l) {
super.float32((float) l);
return;
}
if (l >= Integer.MIN_VALUE && l <= Integer.MAX_VALUE && !canOnlyBeRepresentedAsFloatingPoint) {
super.uint32checked((int) l);
return;
}
super.float64(l);
=======
>>>>>>>
if (l >= Byte.MIN_VALUE && l <= Byte.MAX_VALUE) {
super.int8((byte) l);
return;
}
if (l >= Short.MIN_VALUE && l <= Short.MAX_VALUE) {
super.int16((short) l);
return;
}
if (l >= Integer.MIN_VALUE && l <= Integer.MAX_VALUE) {
super.int32((int) l);
return;
}
if ((long) (float) l == l) {
super.float32(l);
return;
}
super.int64(l);
}
void writeNumber(double l) {
boolean canOnlyBeRepresentedAsFloatingPoint = ((long) l) != l;
if (l >= 0 && l <= 127 && !canOnlyBeRepresentedAsFloatingPoint) {
// used when the value is written directly into the code byte
bytes.writeUnsignedByte((int) l);
return;
}
if (l >= 0) {
if (l <= (1 << 8) - 1 && !canOnlyBeRepresentedAsFloatingPoint) {
super.uint8checked((short) l);
return;
}
if (l <= (1 << 16) - 1 && !canOnlyBeRepresentedAsFloatingPoint) {
super.uint16checked((int) l);
return;
}
if (((double) (float) l) == l) {
super.float32((float) l);
return;
}
if (l <= (1L << 32L) - 1 && !canOnlyBeRepresentedAsFloatingPoint) {
super.uint32checked((int) l);
return;
}
super.float64(l);
return;
}
if (l >= Byte.MIN_VALUE && l <= Byte.MAX_VALUE && !canOnlyBeRepresentedAsFloatingPoint) {
super.int8((byte) l);
return;
}
if (l >= Short.MIN_VALUE && l <= Short.MAX_VALUE && !canOnlyBeRepresentedAsFloatingPoint) {
super.int16((short) l);
return;
}
if (((double) (float) l) == l) {
super.float32((float) l);
return;
}
if (l >= Integer.MIN_VALUE && l <= Integer.MAX_VALUE && !canOnlyBeRepresentedAsFloatingPoint) {
super.uint32checked((int) l);
return;
}
super.float64(l);
<<<<<<<
if (isText(code))
return Integer.valueOf(text());
if (isSmallInt(code))
return code;
return readInt0(code);
=======
if (code >> 4 == BinaryWireHighCode.FLOAT)
return (long) readFloat0(code);
return isText(code) ? readTextAsLong() : readInt0(code);
>>>>>>>
if (isText(code))
return Integer.valueOf(text());
return readInt0(code); |
<<<<<<<
String authMethod = config.getString(RestConfig.AUTHENTICATION_METHOD_CONFIG);
if (enableBasicAuth(authMethod)) {
String realm = getConfiguration().getString(RestConfig.AUTHENTICATION_REALM_CONFIG);
List<String> roles = getConfiguration().getList(RestConfig.AUTHENTICATION_ROLES_CONFIG);
final SecurityHandler securityHandler = createSecurityHandler(realm, roles);
context.setSecurityHandler(securityHandler);
}
=======
if (config.getBoolean(RestConfig.ENABLE_GZIP_COMPRESSION_CONFIG)) {
FilterHolder gzipFilter = new FilterHolder(AsyncGzipFilter.class);
// do not check if .gz file already exists for the requested resource
gzipFilter.setInitParameter("checkGzExists", "false");
gzipFilter.setInitParameter("methods", "GET,POST");
context.addFilter(gzipFilter, "/*", null);
}
configureSecurityHandler(context);
>>>>>>>
configureSecurityHandler(context);
<<<<<<<
public Handler wrapWithGzipHandler(Handler handler) {
if (config.getBoolean(RestConfig.ENABLE_GZIP_COMPRESSION_CONFIG)) {
GzipHandler gzip = new GzipHandler();
gzip.setIncludedMethods("GET", "POST");
gzip.setHandler(handler);
return gzip;
}
return handler;
}
/**
* Used to register any websocket endpoints that will live under the path configured via
* {@link io.confluent.rest.RestConfig#WEBSOCKET_PATH_PREFIX_CONFIG}
*/
protected void registerWebSocketEndpoints(ServerContainer container) {
}
=======
protected void configureSecurityHandler(ServletContextHandler context) {
String authMethod = config.getString(RestConfig.AUTHENTICATION_METHOD_CONFIG);
if (enableBasicAuth(authMethod)) {
String realm = getConfiguration().getString(RestConfig.AUTHENTICATION_REALM_CONFIG);
List<String> roles = getConfiguration().getList(RestConfig.AUTHENTICATION_ROLES_CONFIG);
final SecurityHandler securityHandler = createBasicSecurityHandler(realm, roles);
context.setSecurityHandler(securityHandler);
}
}
>>>>>>>
public Handler wrapWithGzipHandler(Handler handler) {
if (config.getBoolean(RestConfig.ENABLE_GZIP_COMPRESSION_CONFIG)) {
GzipHandler gzip = new GzipHandler();
gzip.setIncludedMethods("GET", "POST");
gzip.setHandler(handler);
return gzip;
}
return handler;
}
/**
* Used to register any websocket endpoints that will live under the path configured via
* {@link io.confluent.rest.RestConfig#WEBSOCKET_PATH_PREFIX_CONFIG}
*/
protected void registerWebSocketEndpoints(ServerContainer container) {
}
protected void configureSecurityHandler(ServletContextHandler context) {
String authMethod = config.getString(RestConfig.AUTHENTICATION_METHOD_CONFIG);
if (enableBasicAuth(authMethod)) {
String realm = getConfiguration().getString(RestConfig.AUTHENTICATION_REALM_CONFIG);
List<String> roles = getConfiguration().getList(RestConfig.AUTHENTICATION_ROLES_CONFIG);
final SecurityHandler securityHandler = createBasicSecurityHandler(realm, roles);
context.setSecurityHandler(securityHandler);
}
} |
<<<<<<<
import android.os.Handler;
import android.os.Looper;
import android.os.Message;
import org.apache.http.Header;
=======
import java.io.IOException;
>>>>>>>
import android.os.Handler;
import android.os.Looper;
import android.os.Message;
import org.apache.http.Header;
import java.io.IOException; |
<<<<<<<
import static com.google.inject.internal.util.$Preconditions.checkNotNull;
=======
>>>>>>> |
<<<<<<<
final BeanRepository beanRepository = new BeanRepository(clientDolphin, dispatcher);
=======
beanRepository = new BeanRepositoryImpl(clientDolphin, dispatcher);
>>>>>>>
final BeanRepository beanRepository = new BeanRepositoryImpl(clientDolphin, dispatcher);
<<<<<<<
return getBeanManager().invoke(Constants.REGISTER_CONTROLLER_COMMAND_NAME).handle((v, e) -> {
if (e != null) {
=======
return getBeanManager().invoke(PlatformConstants.REGISTER_CONTROLLER_COMMAND_NAME).handle((v, e) -> {
if(e != null) {
>>>>>>>
return getBeanManager().invoke(PlatformConstants.REGISTER_CONTROLLER_COMMAND_NAME).handle((v, e) -> {
if (e != null) { |
<<<<<<<
import com.canoo.dp.impl.platform.client.ClientSessionSupportImpl;
import com.canoo.platform.client.HttpURLConnectionFactory;
import com.canoo.platform.remoting.client.ClientConfiguration;
import org.opendolphin.core.client.ClientDolphin;
import org.opendolphin.core.client.ClientModelStore;
import org.opendolphin.core.client.DefaultModelSynchronizer;
import org.opendolphin.core.client.comm.AbstractClientConnector;
import org.opendolphin.core.client.comm.SimpleExceptionHandler;
import org.opendolphin.core.comm.Command;
import org.opendolphin.core.comm.JsonCodec;
import org.opendolphin.util.DolphinRemotingException;
import org.opendolphin.util.Provider;
=======
import com.canoo.dp.impl.client.legacy.ClientDolphin;
import com.canoo.dp.impl.client.legacy.ClientModelStore;
import com.canoo.dp.impl.client.legacy.DefaultModelSynchronizer;
import com.canoo.dp.impl.client.legacy.communication.AbstractClientConnector;
import com.canoo.dp.impl.client.legacy.communication.SimpleExceptionHandler;
import com.canoo.dp.impl.remoting.legacy.communication.Command;
import com.canoo.dp.impl.remoting.legacy.communication.CreatePresentationModelCommand;
import com.canoo.dp.impl.remoting.legacy.communication.JsonCodec;
import com.canoo.platform.remoting.DolphinRemotingException;
import com.canoo.dp.impl.remoting.legacy.util.Provider;
import org.testng.Assert;
>>>>>>>
import com.canoo.dp.impl.remoting.legacy.communication.Command;
import com.canoo.dp.impl.remoting.legacy.communication.JsonCodec;
import com.canoo.platform.client.http.HttpURLConnectionFactory;
import com.canoo.dp.impl.remoting.legacy.util.Provider;
import com.canoo.platform.remoting.DolphinRemotingException;
import com.canoo.platform.remoting.client.ClientConfiguration;
import com.google.gson.Gson;
<<<<<<<
=======
@Test
public void testSimpleCall() throws DolphinRemotingException {
ClientConfiguration clientConfiguration = new ClientConfiguration(getDummyURL(), new DummyUiThreadHandler());
clientConfiguration.setConnectionFactory(new HttpURLConnectionFactory() {
@Override
public HttpURLConnection create(URL url) throws IOException {
return new HttpURLConnection(url) {
@Override
public void disconnect() {
}
@Override
public boolean usingProxy() {
return false;
}
@Override
public void connect() throws IOException {
}
@Override
public OutputStream getOutputStream() throws IOException {
return new ByteArrayOutputStream();
}
@Override
public InputStream getInputStream() throws IOException {
String response = "[{\"pmId\":\"p1\",\"clientSideOnly\":false,\"id\":\"CreatePresentationModel\",\"attributes\":[],\"pmType\":null,\"className\":\"com.canoo.dp.impl.remoting.legacy.communication.CreatePresentationModelCommand\"}]";
return new ByteArrayInputStream(response.getBytes("UTF-8"));
}
@Override
public String getHeaderField(String name) {
if(PlatformConstants.CLIENT_ID_HTTP_HEADER_NAME.equals(name)) {
return "TEST-ID";
}
return super.getHeaderField(name);
}
};
}
});
ClientDolphin clientDolphin = new ClientDolphin();
clientDolphin.setClientModelStore(new ClientModelStore(new DefaultModelSynchronizer(new Provider<AbstractClientConnector>() {
@Override
public AbstractClientConnector get() {
return null;
}
})));
DolphinPlatformHttpClientConnector connector = new DolphinPlatformHttpClientConnector(clientConfiguration, clientDolphin.getModelStore(), new JsonCodec(), new SimpleExceptionHandler());
CreatePresentationModelCommand command = new CreatePresentationModelCommand();
command.setPmId("p1");
Command rawCommand = command;
List<Command> result = connector.transmit(Collections.singletonList(rawCommand));
Assert.assertEquals(result.size(), 1);
Assert.assertTrue(result.get(0) instanceof CreatePresentationModelCommand);
Assert.assertEquals(((CreatePresentationModelCommand) result.get(0)).getPmId(), "p1");
}
>>>>>>> |
<<<<<<<
import com.canoo.dolphin.server.DolphinSession;
import com.canoo.dolphin.server.container.ContainerManager;
import com.canoo.dolphin.server.context.DolphinContext;
=======
import com.canoo.dolphin.server.config.DolphinPlatformConfiguration;
>>>>>>>
import com.canoo.dolphin.server.DolphinSession;
import com.canoo.dolphin.server.config.DolphinPlatformConfiguration;
import com.canoo.dolphin.server.container.ContainerManager;
import com.canoo.dolphin.server.context.DolphinContext;
<<<<<<<
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
=======
import org.slf4j.LoggerFactory;
>>>>>>>
import org.slf4j.LoggerFactory;
<<<<<<<
import java.util.Iterator;
import java.util.ServiceLoader;
=======
import java.util.logging.Logger;
>>>>>>>
import java.util.Iterator;
import java.util.ServiceLoader;
import java.util.logging.Logger;
<<<<<<<
private static final DolphinPlatformBootstrap INSTANCE = new DolphinPlatformBootstrap();
private static final Logger LOG = LoggerFactory.getLogger(DolphinPlatformBootstrap.class);
=======
private static final org.slf4j.Logger LOG = LoggerFactory.getLogger(DolphinPlatformBootstrap.class);
>>>>>>>
private static final DolphinPlatformBootstrap INSTANCE = new DolphinPlatformBootstrap();
private static final org.slf4j.Logger LOG = LoggerFactory.getLogger(DolphinPlatformBootstrap.class); |
<<<<<<<
=======
if (UnstableFeatureFlags.isUseGc()) {
if (commands.size() != 1 || !PlatformConstants.RELEASE_EVENT_BUS_COMMAND_NAME.equals(commands.get(0).getId())) {
NamedCommand garbageCollectionCommand = new NamedCommand(PlatformConstants.GARBAGE_COLLECTION_COMMAND_NAME);
results.addAll(dolphin.getServerConnector().receive(garbageCollectionCommand));
}
}
>>>>>>> |
<<<<<<<
public List<String> getAccessControlAllowHeaders() {
return Collections.unmodifiableList(accessControlAllowHeaders);
}
public void setAccessControlAllowHeaders(List<String> accessControlAllowHeaders) {
this.accessControlAllowHeaders = accessControlAllowHeaders;
}
public List<String> getAccessControlAllowMethods() {
return accessControlAllowMethods;
}
public void setAccessControlAllowMethods(List<String> accessControlAllowMethods) {
this.accessControlAllowMethods = accessControlAllowMethods;
}
public static String getUseCrossSiteOriginFilter() {
return USE_CROSS_SITE_ORIGIN_FILTER;
}
public void setAccessControlAllowCredentials(boolean accessControlAllowCredentials) {
this.accessControlAllowCredentials = accessControlAllowCredentials;
}
public boolean isAccessControlAllowCredentials() {
return accessControlAllowCredentials;
}
public long getAccessControlMaxAge() {
return accessControlMaxAge;
}
public void setAccessControlMaxAge(long accessControlMaxAge) {
this.accessControlMaxAge = accessControlMaxAge;
}
}
=======
public void log(){
Set<Map.Entry<Object, Object>> properties = internalProperties.entrySet();
for(Map.Entry property:properties){
LOG.debug("Dolphin Platform starts with value for "+ property.getKey() +" = "+ property.getValue());
}
}
}
>>>>>>>
public List<String> getAccessControlAllowHeaders() {
return Collections.unmodifiableList(accessControlAllowHeaders);
}
public void setAccessControlAllowHeaders(List<String> accessControlAllowHeaders) {
this.accessControlAllowHeaders = accessControlAllowHeaders;
}
public List<String> getAccessControlAllowMethods() {
return accessControlAllowMethods;
}
public void setAccessControlAllowMethods(List<String> accessControlAllowMethods) {
this.accessControlAllowMethods = accessControlAllowMethods;
}
public static String getUseCrossSiteOriginFilter() {
return USE_CROSS_SITE_ORIGIN_FILTER;
}
public void setAccessControlAllowCredentials(boolean accessControlAllowCredentials) {
this.accessControlAllowCredentials = accessControlAllowCredentials;
}
public boolean isAccessControlAllowCredentials() {
return accessControlAllowCredentials;
}
public long getAccessControlMaxAge() {
return accessControlMaxAge;
}
public void setAccessControlMaxAge(long accessControlMaxAge) {
this.accessControlMaxAge = accessControlMaxAge;
}
public void log(){
Set<Map.Entry<Object, Object>> properties = internalProperties.entrySet();
for(Map.Entry property:properties){
LOG.debug("Dolphin Platform starts with value for "+ property.getKey() +" = "+ property.getValue());
}
}
} |
<<<<<<<
import org.opendolphin.core.client.ClientPresentationModel;
=======
import org.opendolphin.core.client.ClientModelStore;
import org.opendolphin.core.client.ClientPresentationModel;
>>>>>>>
import org.opendolphin.core.client.ClientPresentationModel;
<<<<<<<
List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD);
=======
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER);
>>>>>>>
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD);
<<<<<<<
List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD);
=======
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER);
>>>>>>>
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD);
<<<<<<<
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), hasSize(1));
List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL);
=======
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER), hasSize(1));
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.DEL_FROM_SERVER);
>>>>>>>
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), hasSize(1));
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL);
<<<<<<<
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), hasSize(1));
List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL);
=======
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER), hasSize(1));
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.DEL_FROM_SERVER);
>>>>>>>
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), hasSize(1));
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL);
<<<<<<<
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), hasSize(1));
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL), empty());
List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_SET);
=======
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER), hasSize(1));
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.DEL_FROM_SERVER), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.SET_FROM_SERVER);
>>>>>>>
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), hasSize(1));
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_SET);
<<<<<<<
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), hasSize(1));
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL), empty());
List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_SET);
=======
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER), hasSize(1));
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.DEL_FROM_SERVER), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.SET_FROM_SERVER);
>>>>>>>
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), hasSize(1));
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_SET);
<<<<<<<
List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD);
=======
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER);
>>>>>>>
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD);
<<<<<<<
final List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD);
=======
final List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER);
>>>>>>>
final List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD);
<<<<<<<
List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD);
=======
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER);
>>>>>>>
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD);
<<<<<<<
final List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD);
=======
final List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER);
>>>>>>>
final List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD);
<<<<<<<
List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD);
=======
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER);
>>>>>>>
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD);
<<<<<<<
final List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD);
=======
final List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER);
>>>>>>>
final List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD);
<<<<<<<
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), empty());
List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL);
=======
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.DEL_FROM_SERVER);
>>>>>>>
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL);
<<<<<<<
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), empty());
List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL);
=======
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.DEL_FROM_SERVER);
>>>>>>>
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL);
<<<<<<<
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), empty());
List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL);
=======
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.DEL_FROM_SERVER);
>>>>>>>
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL);
<<<<<<<
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), empty());
List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL);
=======
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.DEL_FROM_SERVER);
>>>>>>>
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL);
<<<<<<<
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), empty());
List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL);
=======
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.DEL_FROM_SERVER);
>>>>>>>
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL);
<<<<<<<
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), empty());
List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL);
=======
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.DEL_FROM_SERVER);
>>>>>>>
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL);
<<<<<<<
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), empty());
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL), empty());
List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_SET);
=======
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER), empty());
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.DEL_FROM_SERVER), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.SET_FROM_SERVER);
>>>>>>>
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), empty());
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_SET);
<<<<<<<
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), empty());
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL), empty());
List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_SET);
=======
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER), empty());
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.DEL_FROM_SERVER), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.SET_FROM_SERVER);
>>>>>>>
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), empty());
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_SET);
<<<<<<<
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), empty());
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL), empty());
List<PresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_SET);
=======
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.ADD_FROM_SERVER), empty());
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.DEL_FROM_SERVER), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.SET_FROM_SERVER);
>>>>>>>
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_ADD), empty());
assertThat(dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_DEL), empty());
List<ClientPresentationModel> changes = dolphin.findAllPresentationModelsByType(DolphinConstants.LIST_SET); |
<<<<<<<
import com.canoo.dp.impl.client.DolphinPlatformHttpClientConnector;
import com.canoo.dp.impl.client.legacy.ClientDolphin;
=======
import com.canoo.dp.impl.client.DolphinPlatformHttpClientConnector;
>>>>>>>
import com.canoo.dp.impl.client.DolphinPlatformHttpClientConnector;
<<<<<<<
import com.canoo.dp.impl.platform.client.http.HttpClientImpl;
import com.canoo.dp.impl.remoting.commands.CreateContextCommand;
=======
import com.canoo.dp.impl.platform.core.PlatformConstants;
import com.canoo.dp.impl.remoting.commands.CreateContextCommand;
>>>>>>>
import com.canoo.dp.impl.platform.client.http.HttpClientImpl;
import com.canoo.dp.impl.platform.core.PlatformConstants;
import com.canoo.dp.impl.remoting.commands.CreateContextCommand;
<<<<<<<
import com.canoo.platform.client.http.HttpURLConnectionFactory;
=======
>>>>>>>
<<<<<<<
import com.canoo.platform.remoting.DolphinRemotingException;
import com.canoo.platform.remoting.client.ClientConfiguration;
import com.google.gson.Gson;
=======
import com.canoo.platform.client.HttpURLConnectionFactory;
import com.canoo.platform.remoting.DolphinRemotingException;
import com.canoo.platform.remoting.client.ClientConfiguration;
import org.testng.Assert;
>>>>>>>
import com.canoo.platform.client.http.HttpURLConnectionFactory;
import com.canoo.platform.remoting.DolphinRemotingException;
import com.canoo.platform.remoting.client.ClientConfiguration;
import com.google.gson.Gson;
import org.testng.Assert;
<<<<<<<
import java.io.ByteArrayOutputStream;
import java.io.IOException;
import java.io.OutputStream;
=======
import java.io.ByteArrayInputStream;
import java.io.ByteArrayOutputStream;
import java.io.IOException;
import java.io.InputStream;
import java.io.OutputStream;
>>>>>>>
import java.io.ByteArrayInputStream;
import java.io.ByteArrayOutputStream;
import java.io.IOException;
import java.io.InputStream;
import java.io.OutputStream;
<<<<<<<
=======
@Test
public void testSimpleCall() throws DolphinRemotingException {
ClientConfiguration clientConfiguration = new ClientConfiguration(getDummyURL(), new DummyUiThreadHandler());
clientConfiguration.setConnectionFactory(new HttpURLConnectionFactory() {
@Override
public HttpURLConnection create(URL url) throws IOException {
return new HttpURLConnection(url) {
@Override
public void disconnect() {
}
@Override
public boolean usingProxy() {
return false;
}
@Override
public void connect() throws IOException {
}
@Override
public OutputStream getOutputStream() throws IOException {
return new ByteArrayOutputStream();
}
@Override
public InputStream getInputStream() throws IOException {
String response = "[{\"pmId\":\"p1\",\"clientSideOnly\":false,\"id\":\"CreatePresentationModel\",\"attributes\":[],\"pmType\":null,\"className\":\"com.canoo.dp.impl.remoting.legacy.communication.CreatePresentationModelCommand\"}]";
return new ByteArrayInputStream(response.getBytes("UTF-8"));
}
@Override
public String getHeaderField(String name) {
if(PlatformConstants.CLIENT_ID_HTTP_HEADER_NAME.equals(name)) {
return "TEST-ID";
}
return super.getHeaderField(name);
}
};
}
});
ClientModelStore clientModelStore = new ClientModelStore(new DefaultModelSynchronizer(new Provider<AbstractClientConnector>() {
@Override
public AbstractClientConnector get() {
return null;
}
}));
DolphinPlatformHttpClientConnector connector = new DolphinPlatformHttpClientConnector(clientConfiguration, clientModelStore, new JsonCodec(), new SimpleExceptionHandler());
CreatePresentationModelCommand command = new CreatePresentationModelCommand();
command.setPmId("p1");
Command rawCommand = command;
List<Command> result = connector.transmit(Collections.singletonList(rawCommand));
Assert.assertEquals(result.size(), 1);
Assert.assertTrue(result.get(0) instanceof CreatePresentationModelCommand);
Assert.assertEquals(((CreatePresentationModelCommand) result.get(0)).getPmId(), "p1");
}
>>>>>>>
@Test
public void testSimpleCall() throws DolphinRemotingException {
ClientConfiguration clientConfiguration = new ClientConfiguration(getDummyURL(), new DummyUiThreadHandler());
clientConfiguration.setConnectionFactory(new HttpURLConnectionFactory() {
@Override
public HttpURLConnection create(URL url) throws IOException {
return new HttpURLConnection(url) {
@Override
public void disconnect() {
}
@Override
public boolean usingProxy() {
return false;
}
@Override
public void connect() throws IOException {
}
@Override
public OutputStream getOutputStream() throws IOException {
return new ByteArrayOutputStream();
}
@Override
public InputStream getInputStream() throws IOException {
String response = "[{\"pmId\":\"p1\",\"clientSideOnly\":false,\"id\":\"CreatePresentationModel\",\"attributes\":[],\"pmType\":null,\"className\":\"com.canoo.dp.impl.remoting.legacy.communication.CreatePresentationModelCommand\"}]";
return new ByteArrayInputStream(response.getBytes("UTF-8"));
}
@Override
public String getHeaderField(String name) {
if (PlatformConstants.CLIENT_ID_HTTP_HEADER_NAME.equals(name)) {
return "TEST-ID";
}
return super.getHeaderField(name);
}
};
}
});
ClientModelStore clientModelStore = new ClientModelStore(new DefaultModelSynchronizer(new Provider<AbstractClientConnector>() {
@Override
public AbstractClientConnector get() {
return null;
}
}));
DolphinPlatformHttpClientConnector connector = new DolphinPlatformHttpClientConnector(clientConfiguration, clientModelStore, new JsonCodec(), new SimpleExceptionHandler(), new HttpClientImpl(new Gson()));
CreatePresentationModelCommand command = new CreatePresentationModelCommand();
command.setPmId("p1");
Command rawCommand = command;
List<Command> result = connector.transmit(Collections.singletonList(rawCommand));
Assert.assertEquals(result.size(), 1);
Assert.assertTrue(result.get(0) instanceof CreatePresentationModelCommand);
Assert.assertEquals(((CreatePresentationModelCommand) result.get(0)).getPmId(), "p1");
} |
<<<<<<<
controllerName = pm.getAttribute(CONTROLLER_NAME);
controllerId = pm.getAttribute(CONTROLLER_ID);
model = pm.getAttribute(MODEL);
=======
controllerNameAttribute = pm.findAttributeByPropertyName(CONTROLLER_NAME);
controllerIdAttribute = pm.findAttributeByPropertyName(CONTROLLER_ID);
modelAttribute = pm.findAttributeByPropertyName(MODEL);
>>>>>>>
controllerNameAttribute = pm.getAttribute(CONTROLLER_NAME);
controllerIdAttribute = pm.getAttribute(CONTROLLER_ID);
modelAttribute = pm.getAttribute(MODEL); |
<<<<<<<
private OpenDolphinFactory openDolphinFactory;
=======
private ControllerRepository controllerRepository;
>>>>>>>
private OpenDolphinFactory openDolphinFactory;
private ControllerRepository controllerRepository;
<<<<<<<
openDolphinFactory = new DefaultOpenDolphinFactory();
=======
controllerRepository = new ControllerRepository();
>>>>>>>
openDolphinFactory = new DefaultOpenDolphinFactory();
controllerRepository = new ControllerRepository();
<<<<<<<
currentContext = new DolphinContext(containerManager, openDolphinFactory);
=======
currentContext = new DolphinContext(containerManager, controllerRepository);
>>>>>>>
currentContext = new DolphinContext(containerManager, controllerRepository, openDolphinFactory); |
<<<<<<<
=======
import com.canoo.platform.remoting.server.event.DolphinEventBus;
import org.apiguardian.api.API;
>>>>>>>
import org.apiguardian.api.API; |
<<<<<<<
import com.canoo.dolphin.PlatformConstants;
import com.canoo.dolphin.util.Assert;
import com.canoo.impl.server.config.DefaultModuleConfig;
import com.canoo.platform.server.spi.PlatformConfiguration;
=======
import com.canoo.impl.platform.core.PlatformConstants;
import com.canoo.impl.server.config.PlatformConfiguration;
import com.canoo.impl.platform.core.Assert;
>>>>>>>
import com.canoo.impl.platform.core.Assert;
import com.canoo.impl.platform.core.PlatformConstants;
import com.canoo.impl.server.config.DefaultModuleConfig;
import com.canoo.platform.server.spi.PlatformConfiguration; |
<<<<<<<
import com.canoo.dolphin.util.Assert;
import com.canoo.impl.server.config.DefaultModuleConfig;
import com.canoo.platform.server.spi.PlatformConfiguration;
=======
import com.canoo.impl.server.config.PlatformConfiguration;
import com.canoo.impl.platform.core.Assert;
>>>>>>>
import com.canoo.impl.platform.core.Assert;
import com.canoo.impl.server.config.DefaultModuleConfig;
import com.canoo.platform.server.spi.PlatformConfiguration; |
Subsets and Splits
No community queries yet
The top public SQL queries from the community will appear here once available.