类com.fasterxml.jackson.annotation.JacksonInject源码实例Demo

下面列出了怎么用com.fasterxml.jackson.annotation.JacksonInject的API类实例代码及写法,或者点击链接到github查看源代码。

源代码1 项目: Bats   文件: EasySubScan.java
@JsonCreator
public EasySubScan(
  @JsonProperty("userName") String userName,
  @JsonProperty("files") List<FileWorkImpl> files,
  @JsonProperty("storage") StoragePluginConfig storageConfig,
  @JsonProperty("format") FormatPluginConfig formatConfig,
  @JacksonInject StoragePluginRegistry engineRegistry,
  @JsonProperty("columns") List<SchemaPath> columns,
  @JsonProperty("selectionRoot") Path selectionRoot,
  @JsonProperty("partitionDepth") int partitionDepth,
  @JsonProperty("schema") TupleSchema schema
  ) throws ExecutionSetupException {
  super(userName);
  this.formatPlugin = (EasyFormatPlugin<?>) engineRegistry.getFormatPlugin(storageConfig, formatConfig);
  Preconditions.checkNotNull(this.formatPlugin);
  this.files = files;
  this.columns = columns;
  this.selectionRoot = selectionRoot;
  this.partitionDepth = partitionDepth;
  this.schema = schema;
}
 
源代码2 项目: Bats   文件: EasyWriter.java
@JsonCreator
public EasyWriter(
    @JsonProperty("child") PhysicalOperator child,
    @JsonProperty("location") String location,
    @JsonProperty("partitionColumns") List<String> partitionColumns,
    @JsonProperty("storageStrategy") StorageStrategy storageStrategy,
    @JsonProperty("storage") StoragePluginConfig storageConfig,
    @JsonProperty("format") FormatPluginConfig formatConfig,
    @JacksonInject StoragePluginRegistry engineRegistry) throws IOException, ExecutionSetupException {

  super(child);
  this.formatPlugin = (EasyFormatPlugin<?>) engineRegistry.getFormatPlugin(storageConfig, formatConfig);
  Preconditions.checkNotNull(formatPlugin, "Unable to load format plugin for provided format config.");
  this.location = location;
  this.partitionColumns = partitionColumns;
  setStorageStrategy(storageStrategy);
}
 
源代码3 项目: Bats   文件: EasyGroupScan.java
@JsonCreator
public EasyGroupScan(
    @JsonProperty("userName") String userName,
    @JsonProperty("files") List<Path> files,
    @JsonProperty("storage") StoragePluginConfig storageConfig,
    @JsonProperty("format") FormatPluginConfig formatConfig,
    @JacksonInject StoragePluginRegistry engineRegistry,
    @JsonProperty("columns") List<SchemaPath> columns,
    @JsonProperty("selectionRoot") Path selectionRoot,
    @JsonProperty("schema") TupleSchema schema
    ) throws IOException, ExecutionSetupException {
  super(ImpersonationUtil.resolveUserName(userName));
  this.selection = FileSelection.create(null, files, selectionRoot);
  this.formatPlugin = Preconditions.checkNotNull((EasyFormatPlugin<?>) engineRegistry.getFormatPlugin(storageConfig, formatConfig),
      "Unable to load format plugin for provided format config.");
  this.columns = columns == null ? ALL_COLUMNS : columns;
  this.selectionRoot = selectionRoot;
  SimpleFileTableMetadataProviderBuilder builder =
      (SimpleFileTableMetadataProviderBuilder) new FileSystemMetadataProviderManager().builder(MetadataProviderManager.MetadataProviderKind.SCHEMA_STATS_ONLY);

  this.metadataProvider = builder.withLocation(selection.getSelectionRoot())
      .withSchema(schema)
      .build();
  initFromSelection(selection, formatPlugin);
}
 
源代码4 项目: Bats   文件: ParquetRowGroupScan.java
@JsonCreator
public ParquetRowGroupScan(@JacksonInject StoragePluginRegistry registry,
                           @JsonProperty("userName") String userName,
                           @JsonProperty("storageConfig") StoragePluginConfig storageConfig,
                           @JsonProperty("formatConfig") FormatPluginConfig formatConfig,
                           @JsonProperty("rowGroupReadEntries") LinkedList<RowGroupReadEntry> rowGroupReadEntries,
                           @JsonProperty("columns") List<SchemaPath> columns,
                           @JsonProperty("readerConfig") ParquetReaderConfig readerConfig,
                           @JsonProperty("selectionRoot") Path selectionRoot,
                           @JsonProperty("filter") LogicalExpression filter) throws ExecutionSetupException {
  this(userName,
      (ParquetFormatPlugin) registry.getFormatPlugin(Preconditions.checkNotNull(storageConfig), Preconditions.checkNotNull(formatConfig)),
      rowGroupReadEntries,
      columns,
      readerConfig,
      selectionRoot,
      filter);
}
 
源代码5 项目: Bats   文件: ParquetWriter.java
@JsonCreator
public ParquetWriter(
        @JsonProperty("child") PhysicalOperator child,
        @JsonProperty("location") String location,
        @JsonProperty("partitionColumns") List<String> partitionColumns,
        @JsonProperty("storageStrategy") StorageStrategy storageStrategy,
        @JsonProperty("storage") StoragePluginConfig storageConfig,
        @JacksonInject StoragePluginRegistry engineRegistry) throws IOException, ExecutionSetupException {

  super(child);
  this.formatPlugin = (ParquetFormatPlugin) engineRegistry.getFormatPlugin(storageConfig, new ParquetFormatConfig());
  Preconditions.checkNotNull(formatPlugin, "Unable to load format plugin for provided format config.");
  this.location = location;
  this.partitionColumns = partitionColumns;
  setStorageStrategy(storageStrategy);
}
 
源代码6 项目: lams   文件: POJOPropertiesCollector.java
protected void _doAddInjectable(JacksonInject.Value injectable, AnnotatedMember m)
{
    if (injectable == null) {
        return;
    }
    Object id = injectable.getId();
    if (_injectables == null) {
        _injectables = new LinkedHashMap<Object, AnnotatedMember>();
    }
    AnnotatedMember prev = _injectables.put(id, m);
    if (prev != null) {
        // 12-Apr-2017, tatu: Let's allow masking of Field by Method
        if (prev.getClass() == m.getClass()) {
            String type = id.getClass().getName();
            throw new IllegalArgumentException("Duplicate injectable value with id '"
                    +String.valueOf(id)+"' (of type "+type+")");
        }
    }
}
 
源代码7 项目: dremio-oss   文件: WriterCommitterPOP.java
@JsonCreator
public WriterCommitterPOP(
    @JsonProperty("props") OpProps props,
    @JsonProperty("tempLocation") String tempLocation,
    @JsonProperty("finalLocation") String finalLocation,
    @JsonProperty("pluginId") StoragePluginId pluginId,
    @JsonProperty("icebergTableProps") IcebergTableProps icebergTableProps,
    @JsonProperty("child") PhysicalOperator child,
    @JacksonInject CatalogService catalogService
    ) {
  super(props, child);
  this.tempLocation = tempLocation;
  this.finalLocation = finalLocation;
  this.icebergTableProps = icebergTableProps;
  this.plugin = Preconditions.checkNotNull(catalogService.<FileSystemPlugin<?>>getSource(pluginId));
}
 
源代码8 项目: dremio-oss   文件: FileSystemCreateTableEntry.java
@JsonCreator
public FileSystemCreateTableEntry(@JsonProperty("userName") String userName,
                                  @JsonProperty("pluginId") StoragePluginId pluginId,
                                  @JsonProperty("formatConfig") FormatPluginConfig formatConfig,
                                  @JsonProperty("location") String location,
                                  @JsonProperty("icebergTableProps") IcebergTableProps icebergTableProps,
                                  @JsonProperty("options") WriterOptions options,
                                  @JacksonInject CatalogService catalogService)
    throws ExecutionSetupException {
  this.userName = userName;
  this.plugin = catalogService.getSource(pluginId);
  this.formatPlugin = plugin.getFormatPlugin(formatConfig);
  this.location = location;
  this.options = options;
  this.icebergTableProps = icebergTableProps;
}
 
源代码9 项目: dremio-oss   文件: EasyWriter.java
@JsonCreator
public EasyWriter(
    @JsonProperty("props") OpProps props,
    @JsonProperty("child") PhysicalOperator child,
    @JsonProperty("userName") String userName,
    @JsonProperty("location") String location,
    @JsonProperty("options") WriterOptions options,
    @JsonProperty("sortColumns") List<String> sortColumns,
    @JsonProperty("pluginId") StoragePluginId pluginId,
    @JsonProperty("format") FormatPluginConfig formatConfig,
    @JacksonInject CatalogService catalogService
    ) {
  super(props, child, options);
  //CatalogService catalogService = null;
  this.plugin = catalogService.getSource(pluginId);
  this.formatPlugin = (EasyFormatPlugin<?>) plugin.getFormatPlugin(formatConfig);
  Preconditions.checkNotNull(formatPlugin, "Unable to load format plugin for provided format config.");
  this.location = location;
}
 
/**
 * Creates a new {@link CouchbaseBucketConfig}.
 *
 * @param rev the revision of the config.
 * @param name the name of the bucket.
 * @param uri the URI for this bucket.
 * @param streamingUri the streaming URI for this bucket.
 * @param partitionInfo partition info for this bucket.
 * @param nodeInfos related node information.
 * @param portInfos port info for the nodes, including services.
 */
@JsonCreator
public DefaultCouchbaseBucketConfig(
    @JsonProperty("rev") long rev,
    @JsonProperty("uuid") String uuid,
    @JsonProperty("name") String name,
    @JsonProperty("uri") String uri,
    @JsonProperty("streamingUri") String streamingUri,
    @JsonProperty("vBucketServerMap") CouchbasePartitionInfo partitionInfo,
    @JsonProperty("nodes") List<NodeInfo> nodeInfos,
    @JsonProperty("nodesExt") List<PortInfo> portInfos,
    @JsonProperty("bucketCapabilities") List<BucketCapabilities> bucketCapabilities,
    @JacksonInject("origin") String origin) {
  super(uuid, name, BucketNodeLocator.VBUCKET, uri, streamingUri, nodeInfos, portInfos, bucketCapabilities, origin);
  this.partitionInfo = partitionInfo;
  this.tainted = partitionInfo.tainted();
  List<NodeInfo> extendedNodeInfos = this.nodes(); // includes ports for SSL services
  this.partitionHosts = buildPartitionHosts(extendedNodeInfos, partitionInfo);
  this.nodesWithPrimaryPartitions = buildNodesWithPrimaryPartitions(nodeInfos, partitionInfo.partitions());
  this.rev = rev;

  // Use bucket capabilities to identify if couchapi is missing (then its ephemeral). If its null then
  // we are running an old version of couchbase which doesn't have ephemeral buckets at all.
  this.ephemeral = bucketCapabilities != null && !bucketCapabilities.contains(BucketCapabilities.COUCHAPI);
}
 
源代码11 项目: Wikidata-Toolkit   文件: ItemDocumentImpl.java
/**
 * Constructor. Creates an object that can be populated during JSON
 * deserialization. Should only be used by Jackson for this very purpose.
 */
@JsonCreator
public ItemDocumentImpl(
		@JsonProperty("id") String jsonId,
		@JsonProperty("labels") @JsonDeserialize(contentAs=TermImpl.class) Map<String, MonolingualTextValue> labels,
		@JsonProperty("descriptions") @JsonDeserialize(contentAs=TermImpl.class) Map<String, MonolingualTextValue> descriptions,
		@JsonProperty("aliases") @JsonDeserialize(using = AliasesDeserializer.class) Map<String, List<MonolingualTextValue>> aliases,
		@JsonProperty("claims") Map<String, List<StatementImpl.PreStatement>> claims,
		@JsonProperty("sitelinks") Map<String, SiteLink> sitelinks,
		@JsonProperty("lastrevid") long revisionId,
		@JacksonInject("siteIri") String siteIri) {
	super(jsonId, labels, descriptions, aliases, claims, revisionId, siteIri);
	if (sitelinks != null) {
		this.sitelinks = sitelinks;
	} else {
		this.sitelinks = Collections.emptyMap();
	}
}
 
源代码12 项目: Wikidata-Toolkit   文件: StatementDocumentImpl.java
/**
 * Constructor used for JSON deserialization with Jackson.
 */
StatementDocumentImpl(
		@JsonProperty("id") String jsonId,
		@JsonProperty("claims") Map<String, List<StatementImpl.PreStatement>> claims,
		@JsonProperty("lastrevid") long revisionId,
		@JacksonInject("siteIri") String siteIri) {
	super(jsonId, revisionId, siteIri);
	if (claims != null) {
		this.claims = new HashMap<>();
		EntityIdValue subject = this.getEntityId();
		for (Entry<String, List<StatementImpl.PreStatement>> entry : claims
				.entrySet()) {
			List<Statement> statements = new ArrayList<>(entry.getValue().size());
			for (StatementImpl.PreStatement statement : entry.getValue()) {
				statements.add(statement.withSubject(subject));
			}
			this.claims.put(entry.getKey(), statements);
		}
	} else {
		this.claims = Collections.emptyMap();
	}
}
 
源代码13 项目: GeoIP2-java   文件: AnonymousIpResponse.java
public AnonymousIpResponse(
        @JacksonInject("ip_address") @JsonProperty("ip_address") String ipAddress,
        @JsonProperty("is_anonymous") boolean isAnonymous,
        @JsonProperty("is_anonymous_vpn") boolean isAnonymousVpn,
        @JsonProperty("is_hosting_provider") boolean isHostingProvider,
        @JsonProperty("is_public_proxy") boolean isPublicProxy,
        @JsonProperty("is_tor_exit_node") boolean isTorExitNode,
        @JacksonInject("network") @JsonProperty("network") @JsonDeserialize(using = NetworkDeserializer.class) Network network
) {
    this.isAnonymous = isAnonymous;
    this.isAnonymousVpn = isAnonymousVpn;
    this.isHostingProvider = isHostingProvider;
    this.isPublicProxy = isPublicProxy;
    this.isTorExitNode = isTorExitNode;
    this.ipAddress = ipAddress;
    this.network = network;
}
 
/**
 * Creates a new {@link MemcachedBucketConfig}.
 *
 * @param env the bootstrap part of environment object.
 * @param rev the revision of the config.
 * @param name the name of the bucket.
 * @param uri the URI for this bucket.
 * @param streamingUri the streaming URI for this bucket.
 * @param nodeInfos related node information.
 * @param portInfos port info for the nodes, including services.
 */
@JsonCreator
public DefaultMemcachedBucketConfig(
        @JacksonInject("env")ConfigParserEnvironment env,
        @JsonProperty("rev") long rev,
        @JsonProperty("uuid") String uuid,
        @JsonProperty("name") String name,
        @JsonProperty("uri") String uri,
        @JsonProperty("streamingUri") String streamingUri,
        @JsonProperty("nodes") List<NodeInfo> nodeInfos,
        @JsonProperty("nodesExt") List<PortInfo> portInfos,
        @JsonProperty("bucketCapabilities") List<BucketCapabilities> bucketCapabilities,
        @JacksonInject("origin") String origin) {
    super(uuid, name, BucketNodeLocator.KETAMA, uri, streamingUri, nodeInfos, portInfos, bucketCapabilities, origin);
    this.env = env;
    this.rev = rev;
    this.ketamaNodes = new TreeMap<>();
    populateKetamaNodes();
}
 
/**
 * Creates a new {@link CouchbaseBucketConfig}.
 *
 * @param rev the revision of the config.
 * @param name the name of the bucket.
 * @param uri the URI for this bucket.
 * @param streamingUri the streaming URI for this bucket.
 * @param partitionInfo partition info for this bucket.
 * @param nodeInfos related node information.
 * @param portInfos port info for the nodes, including services.
 */
@JsonCreator
public DefaultCouchbaseBucketConfig(
    @JsonProperty("rev") long rev,
    @JsonProperty("uuid") String uuid,
    @JsonProperty("name") String name,
    @JsonProperty("uri") String uri,
    @JsonProperty("streamingUri") String streamingUri,
    @JsonProperty("vBucketServerMap") CouchbasePartitionInfo partitionInfo,
    @JsonProperty("nodes") List<NodeInfo> nodeInfos,
    @JsonProperty("nodesExt") List<PortInfo> portInfos,
    @JsonProperty("bucketCapabilities") List<BucketCapabilities> bucketCapabilities,
    @JacksonInject("origin") String origin) {
    super(uuid, name, BucketNodeLocator.VBUCKET, uri, streamingUri, nodeInfos, portInfos, bucketCapabilities, origin);
    this.partitionInfo = partitionInfo;
    this.tainted = partitionInfo.tainted();
    List<NodeInfo> extendedNodeInfos = this.nodes(); // includes ports for SSL services
    this.partitionHosts = buildPartitionHosts(extendedNodeInfos, partitionInfo);
    this.nodesWithPrimaryPartitions = buildNodesWithPrimaryPartitions(nodeInfos, partitionInfo.partitions());
    this.rev = rev;

    // Use bucket capabilities to identify if couchapi is missing (then its ephemeral). If its null then
    // we are running an old version of couchbase which doesn't have ephemeral buckets at all.
    this.ephemeral = bucketCapabilities != null && !bucketCapabilities.contains(BucketCapabilities.COUCHAPI);
}
 
源代码16 项目: suro   文件: KafkaConsumer.java
@JsonCreator
public KafkaConsumer(
        @JsonProperty("consumerProps") Properties consumerProps,
        @JsonProperty("topic") String topic,
        @JsonProperty("readers") int readers,
        @JacksonInject MessageRouter router,
        @JacksonInject ObjectMapper jsonMapper
) {
    Preconditions.checkNotNull(consumerProps);
    Preconditions.checkNotNull(topic);
    Preconditions.checkNotNull(consumerProps.getProperty("group.id"));
    Preconditions.checkNotNull(consumerProps.getProperty("zookeeper.connect"));
    String timeoutStr = consumerProps.getProperty("consumer.timeout.ms");
    Preconditions.checkNotNull(timeoutStr);
    Preconditions.checkArgument(Long.parseLong(timeoutStr) > 0);

    this.consumerProps = consumerProps;
    this.topic = topic;
    this.readers = readers == 0 ? 1 : readers;
    this.router = router;
    this.jsonMapper = jsonMapper;
}
 
源代码17 项目: Bats   文件: LealoneSubScan.java
@JsonCreator
public LealoneSubScan(@JacksonInject StoragePluginRegistry registry,
        @JsonProperty("lealoneStoragePluginConfig") LealoneStoragePluginConfig lealoneStoragePluginConfig,
        @JsonProperty("tabletScanSpecList") LinkedList<LealoneSubScanSpec> tabletScanSpecList,
        @JsonProperty("columns") List<SchemaPath> columns) throws ExecutionSetupException {
    super((String) null);
    lealoneStoragePlugin = (LealoneStoragePlugin) registry.getPlugin(lealoneStoragePluginConfig);
    this.tabletScanSpecList = tabletScanSpecList;
    this.columns = columns;
}
 
源代码18 项目: Bats   文件: LealoneGroupScan.java
@JsonCreator
public LealoneGroupScan(@JsonProperty("scanSpec") LealoneScanSpec scanSpec,
        @JsonProperty("lealoneStoragePluginConfig") LealoneStoragePluginConfig lealoneStoragePluginConfig,
        @JsonProperty("columns") List<SchemaPath> columns, @JacksonInject StoragePluginRegistry pluginRegistry)
        throws IOException, ExecutionSetupException {
    this((LealoneStoragePlugin) pluginRegistry.getPlugin(lealoneStoragePluginConfig), scanSpec, columns);
}
 
源代码19 项目: Bats   文件: FileSystemCreateTableEntry.java
@JsonCreator
public FileSystemCreateTableEntry(@JsonProperty("storageConfig") FileSystemConfig storageConfig,
                                  @JsonProperty("formatConfig") FormatPluginConfig formatConfig,
                                  @JsonProperty("location") String location,
                                  @JsonProperty("partitionColumn") List<String> partitionColumns,
                                  @JsonProperty("storageStrategy") StorageStrategy storageStrategy,
                                  @JacksonInject StoragePluginRegistry engineRegistry)
    throws ExecutionSetupException {
  this.storageConfig = storageConfig;
  this.formatPlugin = engineRegistry.getFormatPlugin(storageConfig, formatConfig);
  this.location = location;
  this.partitionColumns = partitionColumns;
  this.storageStrategy = storageStrategy;
}
 
源代码20 项目: Bats   文件: SystemTableScan.java
@JsonCreator
public SystemTableScan(@JsonProperty("table") SystemTable table,
                       @JsonProperty("maxRecordsToRead") int maxRecordsToRead,
                       @JsonProperty("columns") List<SchemaPath> columns,
                       @JacksonInject StoragePluginRegistry engineRegistry) throws ExecutionSetupException {
  this(table, maxRecordsToRead, (SystemTablePlugin) engineRegistry.getPlugin(SystemTablePluginConfig.INSTANCE));
}
 
源代码21 项目: dremio-flight-connector   文件: FormationWriter.java
@JsonCreator
public FormationWriter(
  @JsonProperty("child") PhysicalOperator child,
  @JsonProperty("props") OpProps props,
  @JsonProperty("location") String location,
  @JsonProperty("options") WriterOptions options,
  @JsonProperty("sortColumns") List<String> sortColumns,
  @JsonProperty("pluginId") StoragePluginId pluginId,
  @JacksonInject CatalogService catalogService
) throws IOException, ExecutionSetupException {
  super(props, child, options);
  //CatalogService catalogService = null;
  this.plugin = catalogService.getSource(pluginId);
  this.location = location;
}
 
源代码22 项目: lams   文件: BasicDeserializerFactory.java
/**
     * Helper method called when there is the explicit "is-creator" with mode of "properties-based"
     *
     * @since 2.9.2
     */
    protected void _addExplicitPropertyCreator(DeserializationContext ctxt,
            BeanDescription beanDesc, CreatorCollector creators,
            CreatorCandidate candidate)
        throws JsonMappingException
    {
        final int paramCount = candidate.paramCount();
        SettableBeanProperty[] properties = new SettableBeanProperty[paramCount];

        for (int i = 0; i < paramCount; ++i) {
            JacksonInject.Value injectId = candidate.injection(i);
            AnnotatedParameter param = candidate.parameter(i);
            PropertyName name = candidate.paramName(i);
            if (name == null) {
                // 21-Sep-2017, tatu: Looks like we want to block accidental use of Unwrapped,
                //   as that will not work with Creators well at all
                NameTransformer unwrapper = ctxt.getAnnotationIntrospector().findUnwrappingNameTransformer(param);
                if (unwrapper != null) {
                    _reportUnwrappedCreatorProperty(ctxt, beanDesc, param);
                    /*
                    properties[i] = constructCreatorProperty(ctxt, beanDesc, UNWRAPPED_CREATOR_PARAM_NAME, i, param, null);
                    ++explicitNameCount;
                    */
                }
                name = candidate.findImplicitParamName(i);
                // Must be injectable or have name; without either won't work
                if ((name == null) && (injectId == null)) {
                    ctxt.reportBadTypeDefinition(beanDesc,
"Argument #%d has no property name, is not Injectable: can not use as Creator %s", i, candidate);
                }
            }
            properties[i] = constructCreatorProperty(ctxt, beanDesc, name, i, param, injectId);
        }
        creators.addPropertyCreator(candidate.creator(), true, properties);
    }
 
源代码23 项目: lams   文件: CreatorCandidate.java
public static CreatorCandidate construct(AnnotationIntrospector intr,
        AnnotatedWithParams creator, BeanPropertyDefinition[] propDefs)
{
    final int pcount = creator.getParameterCount();
    Param[] params = new Param[pcount];
    for (int i = 0; i < pcount; ++i) {
        AnnotatedParameter annParam = creator.getParameter(i);
        JacksonInject.Value injectId = intr.findInjectableValue(annParam);
        params[i] = new Param(annParam, (propDefs == null) ? null : propDefs[i], injectId);
    }
    return new CreatorCandidate(intr, creator, params, pcount);
}
 
源代码24 项目: GeoIP2-java   文件: City.java
public City(
        @JacksonInject("locales") List<String> locales,
        @JsonProperty("confidence") Integer confidence,
        @JsonProperty("geoname_id") Integer geoNameId,
        @JsonProperty("names") Map<String, String> names
) {
    super(locales, geoNameId, names);
    this.confidence = confidence;
}
 
源代码25 项目: lams   文件: CreatorCandidate.java
public Param(AnnotatedParameter p, BeanPropertyDefinition pd,
        JacksonInject.Value i)
{
    annotated = p;
    propDef = pd;
    injection = i;
}
 
源代码26 项目: dremio-oss   文件: StoragePluginId.java
@JsonCreator
public StoragePluginId(
    @JsonProperty("config") SourceConfig config,
    @JsonProperty("capabilities") SourceCapabilities capabilities,
    @JacksonInject ConnectionReader confReader
    ) {
  super();
  this.config = Preconditions.checkNotNull(config);
  this.connection = confReader.getConnectionConf(config);
  this.capabilities = capabilities;
  this.hashCode = Objects.hashCode(config, capabilities);
}
 
源代码27 项目: GeoIP2-java   文件: DomainResponse.java
public DomainResponse(
        @JsonProperty("domain") String domain,
        @JacksonInject("ip_address") @JsonProperty("ip_address") String ipAddress,
        @JacksonInject("network") @JsonProperty("network") @JsonDeserialize(using = NetworkDeserializer.class) Network network
) {
    this.domain = domain;
    this.ipAddress = ipAddress;
    this.network = network;
}
 
源代码28 项目: GeoIP2-java   文件: ConnectionTypeResponse.java
public ConnectionTypeResponse(
        @JsonProperty("connection_type") ConnectionType connectionType,
        @JacksonInject("ip_address") @JsonProperty("ip_address") String ipAddress,
        @JacksonInject("network") @JsonProperty("network") @JsonDeserialize(using = NetworkDeserializer.class) Network network
) {
    this.connectionType = connectionType;
    this.ipAddress = ipAddress;
    this.network = network;
}
 
源代码29 项目: dremio-oss   文件: ParquetWriter.java
@JsonCreator
public ParquetWriter(
    @JsonProperty("props") OpProps props,
    @JsonProperty("child") PhysicalOperator child,
    @JsonProperty("location") String location,
    @JsonProperty("options") WriterOptions options,
    @JsonProperty("pluginId") StoragePluginId pluginId,
    @JacksonInject CatalogService catalogService) throws IOException, ExecutionSetupException {
  super(props, child, options);
  this.plugin = catalogService.getSource(pluginId);
  this.formatPlugin = (ParquetFormatPlugin) plugin.getFormatPlugin(new ParquetFormatConfig());
  Preconditions.checkNotNull(formatPlugin, "Unable to load format plugin for provided format config.");
  this.location = location;
}
 
源代码30 项目: dremio-oss   文件: ElasticMappingSet.java
@JsonCreator
public ElasticIndex(
    @JacksonInject(CurentNameInjectable.CURRENT_NAME) String name,
    @JsonProperty("aliases") List<String> aliases,
    @JsonProperty("mappings") Map<String, ElasticMapping> mappings) {
  this.name = name;
  this.aliases = aliases == null ? ImmutableList.<String>of() : ImmutableList.copyOf(aliases);
  this.mappings = asList(mappings);
}
 
 类方法
 同包方法